2025.09.25 21:01:02.750134 [ 416 ] {} Context: Server was built in debug mode. It will work slowly. 2025.09.25 21:01:02.750820 [ 416 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.25 21:01:03.085920 [ 416 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.25 21:01:03.090267 [ 416 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.25 21:01:07.383875 [ 416 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.09.25 21:01:07.386751 [ 416 ] {} KeeperLogStore: Removing all changelogs 2025.09.25 21:01:07.392269 [ 416 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.25 21:01:07.487301 [ 416 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.25 21:01:07.487774 [ 416 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.25 21:01:07.547587 [ 1060 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.25 21:01:07.938162 [ 416 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.09.25 21:01:07.938717 [ 416 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.09.25 21:01:08.776695 [ 416 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.25 21:01:25.533762 [ 421 ] {456aa978-a77f-44ba-9a20-5e6584f56267} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.25 21:01:39.164617 [ 421 ] {5c18334c-d523-4124-b03b-edf6bfe40d5f} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.25 21:01:57.022487 [ 1059 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.25 21:02:02.269317 [ 1350 ] {} Context: Server was built in debug mode. It will work slowly. 2025.09.25 21:02:02.270174 [ 1350 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.25 21:02:02.839148 [ 1350 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.25 21:02:02.854168 [ 1350 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.25 21:02:07.202663 [ 1350 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.25 21:02:07.297447 [ 1350 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.25 21:02:07.298126 [ 1350 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.25 21:02:07.407837 [ 1989 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.25 21:02:16.649899 [ 1350 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.25 21:03:15.830276 [ 2027 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.09.25 21:03:15.831285 [ 2027 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.09.25 21:03:19.090709 [ 1355 ] {efa6c73a-d2c4-4a00-ae4f-f28e19aace0f} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.80 GiB (attempt to allocate chunk of 1382374 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 169.071533203125, avg_chars_size = 193.28583984374998, limit = 8192): (while reading column Title): (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 292 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41190) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d64434 11. /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 @ 0x0000000010cd58d9 12. /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) @ 0x00000000128f7914 13. /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>>&) @ 0x00000000128f70a6 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 17. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 18. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 19. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 20. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 21. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 23. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 25. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007f3c5a88cac3 31. ? @ 0x00007f3c5a91e850 2025.09.25 21:03:44.966844 [ 1355 ] {efa6c73a-d2c4-4a00-ae4f-f28e19aace0f} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.80 GiB (attempt to allocate chunk of 1382374 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 169.071533203125, avg_chars_size = 193.28583984374998, limit = 8192): (while reading column Title): (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 292 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d64434 11. /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 @ 0x0000000010cd58d9 12. /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) @ 0x00000000128f7914 13. /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>>&) @ 0x00000000128f70a6 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 17. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 18. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 19. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 20. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 21. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 23. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 25. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007f3c5a88cac3 31. ? @ 0x00007f3c5a91e850 2025.09.25 21:04:02.479760 [ 2027 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.09.25 21:04:10.119967 [ 1355 ] {45326c9d-88d0-4a07-83c4-64a66e857988} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1130362 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33778) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010effd07 15. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9352 16. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000126b8c51 17. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:86: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000012834a41 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000012840b4a 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 20. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x000000001283bf05 22. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bd3d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 24. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 25. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 26. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 27. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 29. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 30. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 2025.09.25 21:04:34.385985 [ 1355 ] {45326c9d-88d0-4a07-83c4-64a66e857988} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.30 GiB (attempt to allocate chunk of 1130362 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010effd07 15. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9352 16. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000126b8c51 17. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:86: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000012834a41 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000012840b4a 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 20. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x000000001283bf05 22. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bd3d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 24. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 25. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 26. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 27. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 29. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 30. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 2025.09.25 21:05:21.441353 [ 2043 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {53303125-9975-4221-b621-bca733688e45::202509_1_15_3}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000012aacaf9 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac0f1 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007f3c5a88cac3 14. ? @ 0x00007f3c5a91e850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:05:27.261022 [ 1993 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.25 21:05:28.820984 [ 2921 ] {} Context: Server was built in debug mode. It will work slowly. 2025.09.25 21:05:28.821687 [ 2921 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.25 21:05:29.144751 [ 2921 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.25 21:05:29.153984 [ 2921 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.25 21:05:29.158910 [ 2921 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.25 21:05:33.488500 [ 2921 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.25 21:05:33.521596 [ 2921 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.25 21:05:33.522368 [ 2921 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.25 21:05:33.584086 [ 3555 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.25 21:05:42.656678 [ 2921 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.25 21:05:45.077044 [ 2926 ] {87005b5f-0490-4c6a-b940-9a777a844cbe} 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.10508.altinitytest (altinity build)) (from [::1]:58470) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:05:45.079402 [ 2926 ] {87005b5f-0490-4c6a-b940-9a777a844cbe} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:03.190385 [ 2926 ] {2737bee3-a24a-4772-96f4-044d7d1809cb} 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.10508.altinitytest (altinity build)) (from [::1]:59314) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:03.194697 [ 2926 ] {2737bee3-a24a-4772-96f4-044d7d1809cb} DynamicQueryHandler: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:04.128507 [ 2926 ] {2dc70777-bedf-43ed-ace0-97cd27b37233} 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.10508.altinitytest (altinity build)) (from [::1]:59358) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:04.139562 [ 2926 ] {2dc70777-bedf-43ed-ace0-97cd27b37233} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:06.352440 [ 2926 ] {eb38cd1c-90e1-41eb-8f3a-30995062329c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59514) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:06.396717 [ 2926 ] {eb38cd1c-90e1-41eb-8f3a-30995062329c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:07.046675 [ 2926 ] {fc1882f3-1a1b-41d1-8ae0-ec4e944efa66} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38420) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:07.074136 [ 2926 ] {fc1882f3-1a1b-41d1-8ae0-ec4e944efa66} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:07.476390 [ 3967 ] {6b94a281-f0e8-486b-9c39-2cffb5cfa405} 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.10508.altinitytest (altinity build)) (from [::1]:38482) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:07.497862 [ 3967 ] {6b94a281-f0e8-486b-9c39-2cffb5cfa405} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:08.811870 [ 2929 ] {477e1d00-9c2b-4685-9d5d-d94447650136} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38566) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:08.841074 [ 2929 ] {477e1d00-9c2b-4685-9d5d-d94447650136} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:09.786205 [ 3967 ] {0983c0f0-fb74-40fb-a654-653bc6c80061} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38594) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:09.794431 [ 3967 ] {0983c0f0-fb74-40fb-a654-653bc6c80061} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:10.834002 [ 2926 ] {06e01c1d-2699-4d07-a075-32b3b82c9cf5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52706) (comment: 01552_dict_fixedstring.sql) (in query: DROP DICTIONARY dict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:10.925268 [ 2926 ] {06e01c1d-2699-4d07-a075-32b3b82c9cf5} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:11.255477 [ 2929 ] {61f479af-0722-4d78-b90e-70195a379fad} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38722) (comment: 01552_dict_fixedstring.sql) (in query: DROP DATABASE IF EXISTS test_lnpgunxw ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:11.258612 [ 2929 ] {61f479af-0722-4d78-b90e-70195a379fad} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:11.389196 [ 4184 ] {f3da37e5-ae47-4db0-bfdf-2aa7933dc94b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38714) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:06:11.410440 [ 4184 ] {f3da37e5-ae47-4db0-bfdf-2aa7933dc94b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:11.747390 [ 4057 ] {56e516d0-ce15-4b0f-9e63-c7311b216123} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=4): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52718) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:06:12.238419 [ 4057 ] {56e516d0-ce15-4b0f-9e63-c7311b216123} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=4): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:06:14.718719 [ 4224 ] {79ee662b-3b3a-4cdd-841b-0dd7cf2fcd1f} executeQuery: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52850) (comment: 00507_array_no_params.sh) (in query: CREATE TABLE foo (a Array) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000010c26366 5. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3601b 6. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35abe 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e316 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 9. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:14.740015 [ 4224 ] {79ee662b-3b3a-4cdd-841b-0dd7cf2fcd1f} TCPHandler: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000010c26366 5. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3601b 6. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35abe 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e316 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 9. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:14.792580 [ 2929 ] {b1c46688-e529-4a26-a79b-d88f68f65b19} executeQuery: Code: 57. DB::Exception: Table test_9.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52734) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE ordinary_distinct (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 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 = 0, compact_parts_max_bytes_to_buffer = 280181678, compact_parts_max_granules_to_buffer = 227, compact_parts_merge_max_bytes_to_prefetch_part = 6267624, merge_max_block_size = 4133, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 4452821619, vertical_merge_algorithm_min_rows_to_activate = 1372, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9573941415, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 8485, primary_key_compress_block_size = 57232), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:06:14.814374 [ 2929 ] {b1c46688-e529-4a26-a79b-d88f68f65b19} TCPHandler: Code: 57. DB::Exception: Table test_9.ordinary_distinct 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:06:15.291734 [ 4265 ] {e976230d-cf60-45e6-b8a4-93077f12de91} 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.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57428) (comment: 00005_shard_format_ast_and_remote_table_lambda.sql) (in query: SELECT count() AS `count()` FROM `system`.`one` AS `__table1` WHERE arrayExists(`x` -> (`x` = 1), _CAST([1, 2, 3], 'Array(UInt8)'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:15.299574 [ 4265 ] {e976230d-cf60-45e6-b8a4-93077f12de91} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:15.502605 [ 4057 ] {01346547-5e13-4161-92f5-756042939aca} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52862) (comment: 00005_shard_format_ast_and_remote_table_lambda.sql) (in query: SELECT count() FROM remote('127.0.0.{2,3}', system, one) WHERE arrayExists((x) -> x = 1, [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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:06:15.511875 [ 4057 ] {01346547-5e13-4161-92f5-756042939aca} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:06:16.056196 [ 3975 ] {9ffe900b-7777-49d8-b174-488a89c3ea5e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38918) (comment: 01753_system_zookeeper_query_param_path_long.sh) (in query: DROP DATABASE IF EXISTS test_5is4ikcm ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:16.067510 [ 3975 ] {9ffe900b-7777-49d8-b174-488a89c3ea5e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:16.305799 [ 4057 ] {ed568fac-6fe6-4e96-bef2-9501322f4ee7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38934) (comment: 01753_system_zookeeper_query_param_path_long.sh) (in query: DROP DATABASE IF EXISTS test_5is4ikcm ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:16.309590 [ 4057 ] {ed568fac-6fe6-4e96-bef2-9501322f4ee7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:16.424299 [ 4224 ] {033488d5-0876-41ea-995c-fbb589f6a6ee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38940) (comment: 01753_system_zookeeper_query_param_path_long.sh) (in query: DROP DATABASE IF EXISTS test_5is4ikcm ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:16.437929 [ 4224 ] {033488d5-0876-41ea-995c-fbb589f6a6ee} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:20.225472 [ 4057 ] {70809409-ce57-4cbe-8760-b90b12a1280c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50700) (comment: 02967_analyzer_fuzz.sql) (in query: DROP DATABASE IF EXISTS test_qn11b3wi ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:20.236403 [ 4057 ] {70809409-ce57-4cbe-8760-b90b12a1280c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:22.803675 [ 4224 ] {bd379292-1d26-4564-95b8-43507da9f1e8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43196) (comment: 02815_join_algorithm_setting.sql) (in query: SELECT countIf(explain like '%Algorithm: DirectKeyValueJoin%'), countIf(explain like '%Algorithm: HashJoin%') FROM ( EXPLAIN PLAN actions = 1 SELECT * FROM ( SELECT k AS key FROM t2 ) AS t2 INNER JOIN rdb ON rdb.key = t2.key 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:22.821568 [ 4992 ] {0ef52e80-90c0-4c67-bc32-fc15ad47410b} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_5.`02661_archive_table` UUID '1cbf9c63-29b0-40f7-b7b9-9d7ca5c119a0' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive{1..2}.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:22.838951 [ 4224 ] {bd379292-1d26-4564-95b8-43507da9f1e8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:22.906889 [ 4992 ] {0ef52e80-90c0-4c67-bc32-fc15ad47410b} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43292) (comment: 02661_read_from_archive_zip.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive{1..2}.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:22.930545 [ 4992 ] {0ef52e80-90c0-4c67-bc32-fc15ad47410b} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:23.564268 [ 4056 ] {3b01140b-e59b-485a-ac9e-4665c98516b8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43316) (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 = 22509, min_bytes_for_wide_part = 350838609, ratio_of_defaults_for_sparse_serialization = 0.21016928553581238, replace_long_file_name_to_hash = true, max_file_name_length = 83, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 417775211, compact_parts_max_granules_to_buffer = 107, compact_parts_merge_max_bytes_to_prefetch_part = 29184415, merge_max_block_size = 7880, 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 = 322021098, index_granularity_bytes = 4446240, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 82706, primary_key_compress_block_size = 12655), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 9. /build/contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000012346bc5 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000012a752d5 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713a2 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:06:23.625981 [ 4056 ] {3b01140b-e59b-485a-ac9e-4665c98516b8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 9. /build/contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000012346bc5 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000012a752d5 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713a2 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:06:25.340900 [ 3967 ] {82c645b8-f0d4-42fa-a628-80a0e52dccaf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=5): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52918) (comment: 00002_count_visits.sql) (in query: SELECT sum(Sign) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:06:25.581502 [ 3967 ] {82c645b8-f0d4-42fa-a628-80a0e52dccaf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:06:27.004154 [ 4992 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.015222 [ 4665 ] {73eb1d3e-efa0-485c-9dad-575adaf908eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43324) (comment: 02364_multiSearch_function_family.sql) (in query: select [2] = multiSearchAllPositions(materialize('abcdefgh'), ['bcde']);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.028420 [ 4665 ] {73eb1d3e-efa0-485c-9dad-575adaf908eb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.048666 [ 2926 ] {c5704bac-e398-4a34-8e3a-d643cf9a0598} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_5.`02661_archive_table` UUID 'bf616ed9-63ff-4356-8617-a095144a129b' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive{1,2}.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.107924 [ 2926 ] {c5704bac-e398-4a34-8e3a-d643cf9a0598} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53170) (comment: 02661_read_from_archive_zip.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive{1,2}.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.136455 [ 4056 ] {15261e6c-5f65-444f-9bcf-891eaf18d2bc} 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.10508.altinitytest (altinity build)) (from [::1]:51802) (comment: 00942_mutate_index.sh) (in query: DROP DATABASE IF EXISTS test_rpyi5ego ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:28.147249 [ 4056 ] {15261e6c-5f65-444f-9bcf-891eaf18d2bc} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:28.155888 [ 2926 ] {c5704bac-e398-4a34-8e3a-d643cf9a0598} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:30.810123 [ 4665 ] {3c7f5364-4ca4-4128-9189-ed1da52d3f9d} executeQuery: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53224) (comment: 03101_analyzer_identifiers_3.sql) (in query: SELECT * WHERE *;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x0000000011085a2b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x00000000110827c8 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x00000000110824d5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033579 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:30.816652 [ 4665 ] {3c7f5364-4ca4-4128-9189-ed1da52d3f9d} TCPHandler: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x0000000011085a2b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x00000000110827c8 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x00000000110824d5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033579 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:30.927173 [ 5300 ] {654f8ac2-0385-4b25-b5b7-d5f0b3f1be5f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53282) (comment: 00084_external_aggregation.sql) (in query: SELECT URL, uniq(SearchPhrase) AS u FROM test.hits GROUP BY URL ORDER BY u DESC, URL 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:30.935859 [ 5300 ] {654f8ac2-0385-4b25-b5b7-d5f0b3f1be5f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:31.775925 [ 5326 ] {331d76d9-452d-43be-8a3e-1416d695194b} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_5.`02661_archive_table` UUID '55e322f1-89f3-45de-b98c-b7c3205c818a' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive3.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:31.794183 [ 5326 ] {331d76d9-452d-43be-8a3e-1416d695194b} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53316) (comment: 02661_read_from_archive_zip.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive3.zip :: 02661_read_from_archive_test_5_zip_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:31.819185 [ 5326 ] {331d76d9-452d-43be-8a3e-1416d695194b} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:32.928909 [ 4992 ] {813d5b6b-3313-4403-b6df-c1a5debd036f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=724): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53268) (comment: 03215_view_with_recursive.sql) (in query: SELECT * FROM 03215_test_v;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Sources/RecursiveCTESource.cpp:0: DB::RecursiveCTEChunkGenerator::generate() @ 0x00000000131d794b 9. /build/src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x00000000131d76d0 10. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 11. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 17. /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*) @ 0x0000000012d6ddea 18. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:06:32.952208 [ 4992 ] {813d5b6b-3313-4403-b6df-c1a5debd036f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=724): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Sources/RecursiveCTESource.cpp:0: DB::RecursiveCTEChunkGenerator::generate() @ 0x00000000131d794b 9. /build/src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x00000000131d76d0 10. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 11. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 17. /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*) @ 0x0000000012d6ddea 18. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:06:34.493389 [ 5300 ] {3778cfa8-e671-4851-9a07-3f32ceb31272} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53312) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE test.hits_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:34.501031 [ 5300 ] {3778cfa8-e671-4851-9a07-3f32ceb31272} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:34.750277 [ 5274 ] {76e3d60e-3106-498c-9e77-ad46676fc7c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53360) (comment: 02661_read_from_archive_zip.sh) (in query: DESC file('/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive*.zip :: *.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:34.787232 [ 5274 ] {76e3d60e-3106-498c-9e77-ad46676fc7c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:06:35.790828 [ 4992 ] {75df6ca8-a7de-4ef0-a188-05a5884352b1} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000010 */ CREATE TABLE test_5.`02661_archive_table` UUID 'fade5a3b-2d24-42cd-8dd5-5d722dd64def' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive*.zip :: *.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:35.844091 [ 4992 ] {75df6ca8-a7de-4ef0-a188-05a5884352b1} executeQuery: Code: 57. DB::Exception: Table test_5.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53380) (comment: 02661_read_from_archive_zip.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_zip_archive*.zip :: *.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:35.867215 [ 4992 ] {75df6ca8-a7de-4ef0-a188-05a5884352b1} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:06:39.691020 [ 4665 ] {a2d6a5ac-6e9f-4e88-8ad2-b3339e29ede8} executeQuery: Code: 57. DB::Exception: Table test_c6lgn95g.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53326) (comment: 03222_json_squashing.sql) (in query: CREATE TABLE test (`json` JSON(max_dynamic_paths = 2)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 24195, min_bytes_for_wide_part = 449534883, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 90, min_bytes_for_full_part_storage = 330090017, compact_parts_max_bytes_to_buffer = 86063430, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 9331759, merge_max_block_size = 23459, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5154758452, index_granularity_bytes = 16677767, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 49528, primary_key_compress_block_size = 76245), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:06:39.716959 [ 4665 ] {a2d6a5ac-6e9f-4e88-8ad2-b3339e29ede8} TCPHandler: Code: 57. DB::Exception: Table test_c6lgn95g.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:06:39.860721 [ 5326 ] {15c14638-a8e6-451b-8fb1-22935ae33b2f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43358) (comment: 03222_json_squashing.sql) (in query: DROP DATABASE IF EXISTS test_c6lgn95g ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:39.862680 [ 5326 ] {15c14638-a8e6-451b-8fb1-22935ae33b2f} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:40.278969 [ 4184 ] {b83aa5f6-62d0-49d3-800d-8bb17d461800} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52868) (comment: 01383_remote_ambiguous_column_shard.sql) (in query: DROP DATABASE test_01383;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:40.284550 [ 4184 ] {b83aa5f6-62d0-49d3-800d-8bb17d461800} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:41.668808 [ 5191 ] {e0359f41-4d7a-424a-baa4-13d1e3822053} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53152) (comment: 02765_queries_with_subqueries_profile_events.sh) (in query: SELECT 1 view, 0 enable_analyzer, ProfileEvents['InsertQuery'] InsertQuery, ProfileEvents['SelectQuery'] SelectQuery, ProfileEvents['InsertQueriesWithSubqueries'] InsertQueriesWithSubqueries, -- FIXME: for analyzer it will have one more for sample block ProfileEvents['SelectQueriesWithSubqueries'] SelectQueriesWithSubqueries, ProfileEvents['QueriesWithSubqueries'] QueriesWithSubqueries FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query_id = 'pnubkuydxo' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:06:41.692248 [ 5191 ] {e0359f41-4d7a-424a-baa4-13d1e3822053} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:06:42.203281 [ 4184 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:43.629959 [ 4265 ] {ecbfe7a4-a9e2-4064-8975-07fd837ba71a} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:43.634169 [ 4265 ] {ecbfe7a4-a9e2-4064-8975-07fd837ba71a} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:43.923008 [ 4265 ] {80d015bd-5273-4783-8ba0-ee86a98d09e6} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: -- retry should still fail despite the insert_deduplicate enabled INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:43.931573 [ 4265 ] {80d015bd-5273-4783-8ba0-ee86a98d09e6} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:44.098232 [ 4265 ] {72fbc635-7033-431c-989f-119af518605d} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:44.121431 [ 4265 ] {72fbc635-7033-431c-989f-119af518605d} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:45.728445 [ 4265 ] {dc645e63-dc82-4bb3-b263-4e5ebf2f175d} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:45.734859 [ 4265 ] {dc645e63-dc82-4bb3-b263-4e5ebf2f175d} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:45.937984 [ 4265 ] {4ec5ad7f-a4e1-449f-85e1-9016008d0b9c} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: -- retry should fail despite the insert_deduplicate enabled INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:45.942673 [ 4265 ] {4ec5ad7f-a4e1-449f-85e1-9016008d0b9c} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:46.068179 [ 4265 ] {57eecff2-31e7-40fb-8c3e-bc048d4b8e87} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:46.091602 [ 4265 ] {57eecff2-31e7-40fb-8c3e-bc048d4b8e87} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, unsigned long&, unsigned long&) @ 0x00000000119ffa4b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000012a4c3ea 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x0000000012a4b0b8 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000012a3e278 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x0000000012a3c37b 8. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 9. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 16. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:06:48.286455 [ 4265 ] {98a68981-2673-4cac-b95f-e236882a692d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49428) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: SELECT COUNT() FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:48.288183 [ 4265 ] {98a68981-2673-4cac-b95f-e236882a692d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:48.600005 [ 2926 ] {e43c57fd-e619-4906-a1ac-b5b34af21bf2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35434) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:48.607436 [ 2926 ] {e43c57fd-e619-4906-a1ac-b5b34af21bf2} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:48.812490 [ 4265 ] {e7ce6c49-bcad-466f-b547-8d986aa3b87e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35442) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:48.814971 [ 4265 ] {e7ce6c49-bcad-466f-b547-8d986aa3b87e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:49.257595 [ 2926 ] {196a5122-9d37-48de-a322-0d27a2f5496e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35456) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:49.260199 [ 2926 ] {196a5122-9d37-48de-a322-0d27a2f5496e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:49.349514 [ 2929 ] {1b3c92e9-53f2-4730-b0d6-6c78c6ca51d8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35458) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:49.360228 [ 2929 ] {1b3c92e9-53f2-4730-b0d6-6c78c6ca51d8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:49.451082 [ 2926 ] {377945e8-331a-4f6f-88af-5612c6c92dab} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35464) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:49.454358 [ 2926 ] {377945e8-331a-4f6f-88af-5612c6c92dab} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:49.586623 [ 2926 ] {6944d953-c49f-40c2-a073-cf18ba0b86fb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35478) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: DROP DATABASE IF EXISTS test_gbo9albx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:49.593967 [ 2926 ] {6944d953-c49f-40c2-a073-cf18ba0b86fb} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:51.445425 [ 3602 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8f25176d-6bf0-484f-b27f-d635da64b3f4::202509_1_16_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:52.949611 [ 2929 ] {50cf1715-5046-42a0-9c12-7e27c6491906} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60096) (comment: 02731_in_operator_with_one_size_tuple.sql) (in query: INSERT INTO test SELECT toDate('2023-04-17'), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:06:52.961351 [ 2929 ] {50cf1715-5046-42a0-9c12-7e27c6491906} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:06:53.139730 [ 2926 ] {c34ad060-59be-49db-b059-a001ed9431d6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35516) (comment: 02731_in_operator_with_one_size_tuple.sql) (in query: DROP DATABASE IF EXISTS test_atke856v ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:06:53.151567 [ 2926 ] {c34ad060-59be-49db-b059-a001ed9431d6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:06:55.548772 [ 3975 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.287232 [ 5310 ] {ca39698a-2edf-4a49-9b57-fe42995dd0f1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53256) (comment: 00056_view.sql) (in query: SELECT count() FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.338350 [ 5310 ] {ca39698a-2edf-4a49-9b57-fe42995dd0f1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.509390 [ 3975 ] {01bbc989-9245-49c9-947d-d2996dd2ad4e} executeQuery: Code: 60. DB::Exception: Table test_g8fb1msd.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60132) (comment: 01825_type_json_13.sh) (in query: INSERT INTO t_json_13 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.549015 [ 3975 ] {01bbc989-9245-49c9-947d-d2996dd2ad4e} TCPHandler: Code: 60. DB::Exception: Table test_g8fb1msd.t_json_13 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.588645 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:06:56.955449 [ 2929 ] {024f7a90-e919-4192-9c2e-a71a65220e59} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0): while reading column n at /var/lib/clickhouse/store/934/934c2e04-a2ef-40fb-be9a-7db296e6b0ec/: While executing Log. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60114) (comment: 01091_insert_with_default_json.sql) (in query: SELECT * FROM table_with_complex_default;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3cd0 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2d8b8 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 @ 0x0000000010cd58d9 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>>>&) @ 0x00000000124f61ae 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 2025.09.25 21:06:56.999065 [ 2929 ] {024f7a90-e919-4192-9c2e-a71a65220e59} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0): while reading column n at /var/lib/clickhouse/store/934/934c2e04-a2ef-40fb-be9a-7db296e6b0ec/: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3cd0 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2d8b8 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 @ 0x0000000010cd58d9 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>>>&) @ 0x00000000124f61ae 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 2025.09.25 21:06:57.548767 [ 5191 ] {87900763-700c-4a33-bd13-96d88bd72ced} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_13. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49668) (comment: 01825_type_json_13.sh) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_13;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:57.575557 [ 5191 ] {87900763-700c-4a33-bd13-96d88bd72ced} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_13. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:58.197056 [ 4665 ] {4bbec079-359b-4a82-9799-4a6ba66e6c3f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49692) (comment: 01825_type_json_13.sh) (in query: SELECT obj FROM t_json_13 ORDER BY obj.id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:58.219667 [ 4665 ] {4bbec079-359b-4a82-9799-4a6ba66e6c3f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj FROM t_json_13 ORDER BY obj.id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:58.908349 [ 5191 ] {e37db6f2-2881-49fa-b2a2-3f7424aca1be} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49716) (comment: 01825_type_json_13.sh) (in query: SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:58.944264 [ 5191 ] {e37db6f2-2881-49fa-b2a2-3f7424aca1be} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:06:59.690833 [ 5191 ] {e5b78023-6626-4a6d-888a-de673aafcf8c} executeQuery: Code: 60. DB::Exception: Table test_g8fb1msd.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49736) (comment: 01825_type_json_13.sh) (in query: DROP TABLE t_json_13;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c19c 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>&) @ 0x0000000011571d54 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:06:59.702870 [ 5191 ] {e5b78023-6626-4a6d-888a-de673aafcf8c} TCPHandler: Code: 60. DB::Exception: Table test_g8fb1msd.t_json_13 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c19c 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>&) @ 0x0000000011571d54 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:07:01.742186 [ 2926 ] {28e7fa5c-7eaf-4288-8670-8eb7beea73e3} 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.10508.altinitytest (altinity build)) (from [::1]:49750) (comment: 00054_merge_tree_partitions.sql) (in query: INSERT INTO test.partitions SELECT EventDate + UserID % 365 AS EventDate, CounterID FROM test.hits WHERE CounterID = 1704509;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:01.760046 [ 2926 ] {28e7fa5c-7eaf-4288-8670-8eb7beea73e3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:03.190333 [ 3975 ] {7e630ea6-f32c-4379-87b9-5511f3e2ab11} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49720) (comment: 00061_storage_buffer.sql) (in query: SELECT count() FROM test.hits_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:03.227573 [ 3975 ] {7e630ea6-f32c-4379-87b9-5511f3e2ab11} TCPHandler: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:05.590204 [ 4665 ] {093e42cb-1b28-4173-81a7-95bf0b64384b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49798) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:07:05.651906 [ 4665 ] {093e42cb-1b28-4173-81a7-95bf0b64384b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:07:05.742375 [ 4265 ] {01600_log_queries_with_extensive_info_004_err} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49852) (comment: 01600_log_queries_with_extensive_info.sh) (in query: select k from test_log_queries.logtable where i > ''), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000c6cb8bb 5. ? @ 0x0000000010d3400c 6. /build/src/DataTypes/Serializations/SerializationNumber.cpp:34: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010d33e6a 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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 @ 0x0000000008c1e152 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c03ca6 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&, bool&) @ 0x0000000011625c38 21. /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>>&) @ 0x0000000011654949 22. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 26. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 27. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 28. /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&) @ 0x000000001166213c 29. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 30. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 31. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 2025.09.25 21:07:05.764369 [ 4265 ] {01600_log_queries_with_extensive_info_004_err} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000c6cb8bb 5. ? @ 0x0000000010d3400c 6. /build/src/DataTypes/Serializations/SerializationNumber.cpp:34: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010d33e6a 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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 @ 0x0000000008c1e152 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c03ca6 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&, bool&) @ 0x0000000011625c38 21. /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>>&) @ 0x0000000011654949 22. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 26. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 27. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 28. /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&) @ 0x000000001166213c 29. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 30. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 31. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 2025.09.25 21:07:08.666959 [ 5795 ] {b22a5914-a008-42d2-81f0-a68b66fab4d4} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38288) (comment: 03261_optimize_rewrite_array_exists_to_has_crash.sql) (in query: SELECT 1 FROM rewrite INNER JOIN rewrite AS y ON ( SELECT 1 ) INNER JOIN rewrite AS z ON 1 SETTINGS optimize_rewrite_array_exists_to_has=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011685d45 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:08.700246 [ 5795 ] {b22a5914-a008-42d2-81f0-a68b66fab4d4} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011685d45 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:09.643683 [ 5310 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59984, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:09.760488 [ 4184 ] {8229cf41-c302-4523-a516-c4a9e0ac4159} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float64'). (CANNOT_PARSE_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38320) (comment: 02900_issue_55858.sql) (in query: select cast('2023-01-01' as Float64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat64, 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)::NameToFloat64, 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&&) @ 0x00000000071eb695 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071e63a8 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:07:09.774968 [ 4184 ] {8229cf41-c302-4523-a516-c4a9e0ac4159} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float64'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat64, 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)::NameToFloat64, 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&&) @ 0x00000000071eb695 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071e63a8 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:07:09.980540 [ 4184 ] {e6a2a305-502c-42de-86da-514d1b6e70e3} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float32'). (CANNOT_PARSE_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38320) (comment: 02900_issue_55858.sql) (in query: select cast('2023-01-01' as Float32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat32, 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)::NameToFloat32, 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&&) @ 0x00000000071dbe89 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071d6be8 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:07:09.995519 [ 4184 ] {e6a2a305-502c-42de-86da-514d1b6e70e3} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float32'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat32, 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)::NameToFloat32, 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&&) @ 0x00000000071dbe89 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071d6be8 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:07:10.242331 [ 4184 ] {e7afebe2-5584-4a30-a9de-47e632722b64} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat32('2023-01-01'). (CANNOT_PARSE_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38320) (comment: 02900_issue_55858.sql) (in query: select toFloat32('2023-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat32, 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)::NameToFloat32, 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&&) @ 0x00000000071dbe89 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071d6be8 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:07:10.273155 [ 4184 ] {e7afebe2-5584-4a30-a9de-47e632722b64} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat32('2023-01-01'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat32, 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)::NameToFloat32, 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&&) @ 0x00000000071dbe89 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071d6be8 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:07:10.593577 [ 4184 ] {2a7be3ca-657a-4317-a729-358c05324977} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat64('2023-01-01'). (CANNOT_PARSE_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38320) (comment: 02900_issue_55858.sql) (in query: select toFloat64('2023-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat64, 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)::NameToFloat64, 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&&) @ 0x00000000071eb695 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071e63a8 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:07:10.605131 [ 4184 ] {2a7be3ca-657a-4317-a729-358c05324977} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat64('2023-01-01'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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)::NameToFloat64, 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)::NameToFloat64, 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&&) @ 0x00000000071eb695 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071e63a8 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:07:10.674848 [ 4184 ] {01e7cb79-76a7-4c0e-b804-6d4bdaec068d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38320) (comment: 02900_issue_55858.sql) (in query: select toFloat32OrZero('2023-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:10.680170 [ 4184 ] {01e7cb79-76a7-4c0e-b804-6d4bdaec068d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:12.239417 [ 4265 ] {ca826719-121f-441c-8577-286d7164f02a} executeQuery: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38360) (comment: 02701_invalid_having_NOT_AN_AGGREGATE.sql) (in query: SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer=1 -- { serverError NOT_AN_AGGREGATE } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001108483e 5. /build/src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000011083805 6. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103358e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:12.248347 [ 4265 ] {ca826719-121f-441c-8577-286d7164f02a} TCPHandler: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001108483e 5. /build/src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000011083805 6. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103358e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:19.327785 [ 4649 ] {fca0f3de-29d7-484c-a46d-7e4e0a57cc0c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43208) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT 'Simple functions with non compilable function without 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:19.339090 [ 4649 ] {fca0f3de-29d7-484c-a46d-7e4e0a57cc0c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:21.276021 [ 5310 ] {d9928e19-cdd0-4107-b5da-4ba18774f64c} 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.10508.altinitytest (altinity build)) (from [::1]:53598) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x0000000011683ad5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116809bd 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&) @ 0x000000001166d18d 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:07:21.286295 [ 5310 ] {d9928e19-cdd0-4107-b5da-4ba18774f64c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x0000000011683ad5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116809bd 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&) @ 0x000000001166d18d 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:07:22.033468 [ 4265 ] {701499c3-cc98-442d-a3c9-6db09e65475f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53616) (comment: 00053_replicate_segfault.sql) (in query: SELECT count() > 0 FROM (SELECT ParsedParams.Key1 AS p FROM test.visits WHERE arrayAll(y -> arrayExists(x -> y != x, p), p)) ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cdd80e 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:07:22.082393 [ 4265 ] {701499c3-cc98-442d-a3c9-6db09e65475f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cdd80e 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:07:22.552480 [ 4265 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50736, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:24.424884 [ 5310 ] {697fa26e-9834-4a99-aa51-a0421fadf1f3} 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.10508.altinitytest (altinity build)) (from [::1]:53598) (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 USING val 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011685155 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:24.426460 [ 5310 ] {697fa26e-9834-4a99-aa51-a0421fadf1f3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011685155 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:25.539944 [ 4265 ] {5821d365-847a-4dfc-827f-c6c66914e9a6} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: ALTER TABLE log_for_alter MODIFY SETTING aaa=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf5d7 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ec91 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:25.547088 [ 4265 ] {5821d365-847a-4dfc-827f-c6c66914e9a6} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf5d7 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ec91 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:25.954784 [ 4265 ] {bb00d194-7d93-4e56-9a45-a2b8e8295a7e} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: ALTER TABLE table_for_alter MODIFY SETTING index_granularity=555;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6146 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:25.957772 [ 4265 ] {bb00d194-7d93-4e56-9a45-a2b8e8295a7e} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6146 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.420911 [ 4265 ] {b74048e9-af0a-4262-b61e-63386a782064} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_13.table_for_alter (fce8e3c9-1043-4cc9-a55c-ee74f154c906)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: INSERT INTO table_for_alter 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.423598 [ 4265 ] {b74048e9-af0a-4262-b61e-63386a782064} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_13.table_for_alter (fce8e3c9-1043-4cc9-a55c-ee74f154c906)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.634729 [ 4265 ] {afe00f8e-6d1d-4e06-ace3-82aa899208a9} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_13.table_for_alter (fce8e3c9-1043-4cc9-a55c-ee74f154c906)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: INSERT INTO table_for_alter 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.636455 [ 4265 ] {afe00f8e-6d1d-4e06-ace3-82aa899208a9} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_13.table_for_alter (fce8e3c9-1043-4cc9-a55c-ee74f154c906)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.781919 [ 4265 ] {cf09ebde-ce51-43a4-8495-08182cf9fa58} executeQuery: Code: 115. DB::Exception: Unknown setting 'xxx_yyy'. (UNKNOWN_SETTING) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: ALTER TABLE table_for_alter MODIFY SETTING xxx_yyy=124;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000001096caf0 5. /build/contrib/llvm-project/libcxx/include/vector:1500: DB::BaseSettings::set(std::basic_string_view>, DB::Field const&) @ 0x000000000c892585 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x00000000127ab2db 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4dff 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.785190 [ 4265 ] {cf09ebde-ce51-43a4-8495-08182cf9fa58} TCPHandler: Code: 115. DB::Exception: Unknown setting 'xxx_yyy'. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000001096caf0 5. /build/contrib/llvm-project/libcxx/include/vector:1500: DB::BaseSettings::set(std::basic_string_view>, DB::Field const&) @ 0x000000000c892585 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x00000000127ab2db 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4dff 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.887378 [ 4665 ] {f29d97c7-467d-4bb2-8814-d1d030220c83} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43192) (comment: 00159_parallel_formatting_http.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a,MobilePhoneModel as b,ClientIP6 as c FROM test.hits ORDER BY a,b,c LIMIT 1000000 Format 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012ceca91 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x0000000012cec4e8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012cebe7e 10. /build/src/Formats/FormatFactory.cpp:522: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce393d 11. /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&)>) @ 0x000000001191412d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:07:26.893131 [ 4665 ] {f29d97c7-467d-4bb2-8814-d1d030220c83} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012ceca91 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x0000000012cec4e8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012cebe7e 10. /build/src/Formats/FormatFactory.cpp:522: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce393d 11. /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&)>) @ 0x000000001191412d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:28.024880 [ 4265 ] {fd8cbcfc-327e-42b2-894f-60a5d2122a2b} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: ALTER TABLE table_for_reset_setting MODIFY SETTING index_granularity=555;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6146 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:28.028637 [ 4265 ] {fd8cbcfc-327e-42b2-894f-60a5d2122a2b} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6146 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:28.092888 [ 4665 ] {a7c85838-63c7-4ff5-bb5f-1f9cc6ba9dc4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52802) (comment: 00045_uniq_upto.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM test.visits GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:07:28.110257 [ 4665 ] {a7c85838-63c7-4ff5-bb5f-1f9cc6ba9dc4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:07:28.550148 [ 4265 ] {d5507ab7-0b85-4a6d-8067-f63344b2bbbe} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 320.00 B) in table 'test_13.table_for_reset_setting (3e0b267b-16c3-4743-bb61-da09b5e3e79b)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: INSERT INTO table_for_reset_setting 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:28.552526 [ 4265 ] {d5507ab7-0b85-4a6d-8067-f63344b2bbbe} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 320.00 B) in table 'test_13.table_for_reset_setting (3e0b267b-16c3-4743-bb61-da09b5e3e79b)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000012d715e8 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe1ba 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:07:29.430688 [ 4265 ] {ce8b19d8-d5db-4ade-97de-81d723282f36} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: ALTER TABLE table_for_reset_setting RESET SETTING index_granularity;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a609d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:29.433562 [ 4265 ] {ce8b19d8-d5db-4ade-97de-81d723282f36} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a609d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:29.518615 [ 4265 ] {45f26795-3f58-4ffd-9465-f22b7c01bf5c} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53660) (comment: 00980_merge_alter_settings.sql) (in query: -- don't execute alter with incorrect setting ALTER TABLE table_for_reset_setting RESET SETTING merge_with_ttl_timeout, unknown_setting;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a5d74 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:29.522873 [ 4265 ] {45f26795-3f58-4ffd-9465-f22b7c01bf5c} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a5d74 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:30.602371 [ 5795 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:30.667565 [ 5600 ] {703035c0-75eb-4296-87e7-c9e1aebb03dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/1f5/1f5dde2e-b2d7-4e9d-9554-6a73596d18e1/202509_70_70_0/ in table system.text_log (1f5dde2e-b2d7-4e9d-9554-6a73596d18e1) located on disk default of type local, from mark 0 with max_rows_to_read = 568): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53648) (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_2365529120' AND initial_query_id = 'query_id_memory_bound_merging_2365529120' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e95d8 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e95d8 25. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 26. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 27. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 28. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 29. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 30. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 31. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 2025.09.25 21:07:30.727247 [ 5600 ] {703035c0-75eb-4296-87e7-c9e1aebb03dd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/1f5/1f5dde2e-b2d7-4e9d-9554-6a73596d18e1/202509_70_70_0/ in table system.text_log (1f5dde2e-b2d7-4e9d-9554-6a73596d18e1) located on disk default of type local, from mark 0 with max_rows_to_read = 568): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e95d8 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e95d8 25. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 26. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 27. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 28. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 29. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 30. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 31. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 2025.09.25 21:07:33.342995 [ 4265 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60474, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:34.298911 [ 7261 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:44430, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:35.077952 [ 7271 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:44452, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:35.079020 [ 7272 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60478, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:40.728793 [ 5326 ] {9227efd6-a0e0-4820-8c24-f9fa5db3e5c7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49414) (comment: 01383_remote_ambiguous_column_shard.sql) (in query: DROP DATABASE IF EXISTS test_01383;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:40.738956 [ 5326 ] {9227efd6-a0e0-4820-8c24-f9fa5db3e5c7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:41.311836 [ 4665 ] {8adc5035-6b95-430b-90d9-d8bdc0ad78a3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57978) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`x` AS `x` FROM `test_13`.`02535_custom_key_rmt` AS `__table1` WHERE (sipHash64(`x`) >= 6148914691236517205) AND (sipHash64(`x`) < 12297829382473034410) SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:41.331426 [ 4665 ] {8adc5035-6b95-430b-90d9-d8bdc0ad78a3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:41.371184 [ 7272 ] {a5fa1162-5361-47c8-8bf8-09c21daf1c3c} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=731). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49798) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT * FROM 02535_custom_key_rmt SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:07:41.380653 [ 7272 ] {a5fa1162-5361-47c8-8bf8-09c21daf1c3c} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=731). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:07:41.496669 [ 7260 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57990, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:41.536165 [ 7599 ] {9fb975c8-e1b0-4248-b138-b0516fdea64a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49802) (comment: 01383_remote_ambiguous_column_shard.sql) (in query: DROP DATABASE IF EXISTS test_01383;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:41.664030 [ 7599 ] {9fb975c8-e1b0-4248-b138-b0516fdea64a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:42.613503 [ 7896 ] {d00be4dc-230e-4c8a-84b8-ed82ee164aeb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49822) (comment: 01383_remote_ambiguous_column_shard.sql) (in query: DROP DATABASE IF EXISTS test_01383;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:42.621265 [ 7896 ] {d00be4dc-230e-4c8a-84b8-ed82ee164aeb} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:42.709031 [ 7604 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52518, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:43.035700 [ 7903 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59896, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:43.037466 [ 7901 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42134, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:46.603237 [ 7936 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:48.925014 [ 7903 ] {8d18fe7a-caa1-460e-8c1d-4c7a76c57f72} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010cc509e 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8323 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9f7f0 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8fc0e 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&) @ 0x000000001101c432 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100ccc2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d300 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000011010591 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bcbb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e27b 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 @ 0x000000001100bbed 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100b8ae 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&) @ 0x00000000116475af 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:07:48.928364 [ 7903 ] {8d18fe7a-caa1-460e-8c1d-4c7a76c57f72} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010cc509e 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8323 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9f7f0 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8fc0e 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&) @ 0x000000001101c432 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100ccc2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d300 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000011010591 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bcbb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e27b 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 @ 0x000000001100bbed 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100b8ae 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&) @ 0x00000000116475af 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:07:50.773673 [ 8178 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:32818, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:51.376015 [ 7903 ] {20e37578-4014-4afc-953b-e47eac5b4fa1} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- can't use bloom_filter with `hasAny` on non-constant arguments (just like `has`) SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:51.397795 [ 7903 ] {20e37578-4014-4afc-953b-e47eac5b4fa1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:51.710224 [ 7903 ] {cca6a407-6c8d-44c9-9fce-4c368fe78912} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- NULLs are not Ok SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:51.714169 [ 7903 ] {cca6a407-6c8d-44c9-9fce-4c368fe78912} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:51.949259 [ 7903 ] {586aa582-dd33-4314-ac50-c4bd2da32f79} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:51.952367 [ 7903 ] {586aa582-dd33-4314-ac50-c4bd2da32f79} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:52.054247 [ 7903 ] {d3918cfc-81c8-41a3-bd93-9363e1e2eace} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- non-compatible types SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010cc509e 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8323 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9f7f0 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8fc0e 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&) @ 0x000000001101c432 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100ccc2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d300 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000011010591 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bcbb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e27b 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 @ 0x000000001100bbed 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100b8ae 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&) @ 0x00000000116475af 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:07:52.057411 [ 7903 ] {d3918cfc-81c8-41a3-bd93-9363e1e2eace} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010cc509e 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8323 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9f7f0 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8fc0e 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&) @ 0x000000001101c432 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100ccc2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d300 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000011010591 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bcbb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e27b 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 @ 0x000000001100bbed 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100b8ae 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&) @ 0x00000000116475af 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:07:52.145259 [ 8178 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42674, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:52.182746 [ 4665 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:32830, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:52.224228 [ 7903 ] {072ae704-d83d-4dd1-b079-6f46dd0f5fa8} 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.10508.altinitytest (altinity build)) (from [::1]:49864) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:52.226677 [ 7903 ] {072ae704-d83d-4dd1-b079-6f46dd0f5fa8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:07:53.820399 [ 2929 ] {1ac24364-55e2-4226-982f-5055379efb92} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51380) (comment: 00080_array_join_and_union.sql) (in query: SELECT count() FROM (SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 LIMIT 10 UNION ALL SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d2385e 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddc51 15. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 17. /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) @ 0x00000000128f5f4c 18. /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&) @ 0x000000001282d934 19. /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 @ 0x000000001282a6ee 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 22. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 24. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 25. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 27. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 28. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 29. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 30. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 31. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 2025.09.25 21:07:54.062075 [ 2929 ] {1ac24364-55e2-4226-982f-5055379efb92} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d2385e 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddc51 15. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 17. /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) @ 0x00000000128f5f4c 18. /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&) @ 0x000000001282d934 19. /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 @ 0x000000001282a6ee 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 22. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 24. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 25. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 27. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 28. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 29. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 30. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 31. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 2025.09.25 21:07:54.677628 [ 7603 ] {394deaaa-fb2d-4052-89ca-cda7b319a761} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32846) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT DISTINCT `__table1`.`PredLastVisit` AS `x` FROM `test`.`visits` AS `__table1` ORDER BY `__table1`.`VisitID` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:07:54.683838 [ 7603 ] {394deaaa-fb2d-4052-89ca-cda7b319a761} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:07:54.727052 [ 7629 ] {03f0f06b-f16b-43b3-8817-5d5cdffc396b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51396) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:07:54.744650 [ 7629 ] {03f0f06b-f16b-43b3-8817-5d5cdffc396b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:07:55.231957 [ 5326 ] {82c40823-b62e-4b8c-9fad-34723c71ee40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51434) (comment: 00084_external_aggregation.sql) (in query: SELECT URL, uniq(SearchPhrase) AS u FROM test.hits GROUP BY URL ORDER BY u DESC, URL 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:55.243252 [ 5326 ] {82c40823-b62e-4b8c-9fad-34723c71ee40} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:55.689892 [ 7628 ] {8825a43f-9d44-4534-b728-6d33b9334d8e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51452) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_rmt_hash) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:55.708232 [ 7628 ] {8825a43f-9d44-4534-b728-6d33b9334d8e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:56.024560 [ 4992 ] {b4d38a43-8e62-4d2c-94b6-3ff47642fe27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44418) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE (`y` >= 1431655765) AND (`y` < 2863311530) GROUP BY `__table1`.`y` ORDER BY `__table1`.`y` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:56.036529 [ 7261 ] {35f17405-4b9e-40e1-aaa5-cac1dfb26f61} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44438) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE `y` < 1431655765 GROUP BY `__table1`.`y` ORDER BY `__table1`.`y` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:56.066756 [ 4992 ] {b4d38a43-8e62-4d2c-94b6-3ff47642fe27} 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]:44418). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:56.067988 [ 7261 ] {35f17405-4b9e-40e1-aaa5-cac1dfb26f61} 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]:44438). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:07:56.068521 [ 4992 ] {b4d38a43-8e62-4d2c-94b6-3ff47642fe27} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:56.069030 [ 7261 ] {35f17405-4b9e-40e1-aaa5-cac1dfb26f61} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:56.072243 [ 7261 ] {35f17405-4b9e-40e1-aaa5-cac1dfb26f61} TCPHandler: Client has gone away. 2025.09.25 21:07:56.073716 [ 4992 ] {b4d38a43-8e62-4d2c-94b6-3ff47642fe27} TCPHandler: Client has gone away. 2025.09.25 21:07:57.381715 [ 8204 ] {8cf5ac09-7099-45c5-9a69-ab502266e68a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48810) (comment: 00031_array_enumerate_uniq.sql) (in query: SELECT UserID, arrayEnumerateUniq(groupArray(SearchPhrase)) AS arr FROM ( SELECT UserID, SearchPhrase FROM test.hits WHERE CounterID = 1704509 AND UserID IN ( SELECT UserID FROM test.hits WHERE notEmpty(SearchPhrase) AND CounterID = 1704509 GROUP BY UserID HAVING count() > 1 ) ORDER BY UserID, WatchID ) WHERE notEmpty(SearchPhrase) GROUP BY UserID HAVING length(arr) > 1 ORDER BY UserID LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:57.489134 [ 8204 ] {8cf5ac09-7099-45c5-9a69-ab502266e68a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:57.834506 [ 7915 ] {7ab726f9-c2bf-4d16-822a-eea053e8b17d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=25, jobs=25). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48794) (comment: 00150_quantiles_timing_precision.sql) (in query: SELECT CounterID, quantileTiming(0.5)(SendTiming) AS qt, least(30000, quantileExact(0.5)(SendTiming)) AS qe, count() AS c, round(abs(qt - qe) / greatest(qt, qe) AS diff, 3) AS rounded_diff FROM test.hits WHERE SendTiming != -1 GROUP BY CounterID HAVING diff != 0 ORDER BY diff DESC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:58.067658 [ 7915 ] {7ab726f9-c2bf-4d16-822a-eea053e8b17d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=25, jobs=25). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:07:58.597828 [ 8460 ] {4a858cee-54ba-4250-88ce-6ca47c70c432} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48836) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE IF EXISTS test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:58.614233 [ 8460 ] {4a858cee-54ba-4250-88ce-6ca47c70c432} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:58.697926 [ 7628 ] {02ea6014-8bf7-435d-9085-00ce4f515528} 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.10508.altinitytest (altinity build)) (from [::1]:48830) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:58.716472 [ 7628 ] {02ea6014-8bf7-435d-9085-00ce4f515528} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:07:59.329600 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:07:59.777835 [ 7933 ] {6434fcff-d8df-49da-9c4b-f9d741ec354c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59960) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE positiveModulo(cityHash64(`y`), 3) = 2 GROUP BY `__table1`.`y` ORDER BY `__table1`.`y` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:07:59.785229 [ 7933 ] {6434fcff-d8df-49da-9c4b-f9d741ec354c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:00.040744 [ 8473 ] {da53b194-d5a4-47d5-a20a-c444bd221c65} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48880) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_rmt_hash) 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:00.052266 [ 8473 ] {da53b194-d5a4-47d5-a20a-c444bd221c65} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:00.053209 [ 8203 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59968, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:00.166191 [ 5795 ] {4f7ae872-73d5-4b9d-bf3d-b539c5139f1c} 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]:56658). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56658) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE positiveModulo(cityHash64(`y`), 3) = 1 GROUP BY `__table1`.`y` ORDER BY `__table1`.`y` 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbf92f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf64a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:00.184164 [ 5795 ] {4f7ae872-73d5-4b9d-bf3d-b539c5139f1c} 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]:56658). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:00.187334 [ 5795 ] {4f7ae872-73d5-4b9d-bf3d-b539c5139f1c} 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]:56658). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbf92f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf64a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:00.201312 [ 5795 ] {4f7ae872-73d5-4b9d-bf3d-b539c5139f1c} TCPHandler: Client has gone away. 2025.09.25 21:08:00.730822 [ 8461 ] {0bc73dbd-4a1f-48b6-9e0e-704092a5dabf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48862) (comment: 00042_any_left_join.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:00.804889 [ 8461 ] {0bc73dbd-4a1f-48b6-9e0e-704092a5dabf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:01.373041 [ 8190 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56492, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:02.792004 [ 7597 ] {31c67e13-b13e-463c-9395-f1b850e295df} 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.10508.altinitytest (altinity build)) (from [::1]:48912) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE toInt32(CounterID) = 1731;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:02.795855 [ 7597 ] {31c67e13-b13e-463c-9395-f1b850e295df} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:02.815991 [ 8200 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56676, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:03.680307 [ 5191 ] {4468c13f-d54b-4d6d-8e2d-c754dfe30215} 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.10508.altinitytest (altinity build)) (from [::1]:48962) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_rmt_hash) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:03.698449 [ 5191 ] {4468c13f-d54b-4d6d-8e2d-c754dfe30215} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:05.983826 [ 8184 ] {ac3dc790-77bd-4d05-8d97-c2a508f26fe2} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.002058 [ 8184 ] {ac3dc790-77bd-4d05-8d97-c2a508f26fe2} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.149473 [ 8184 ] {5ed35889-e73b-435c-b522-ce26cb3e2ede} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[]], []]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.152043 [ 8184 ] {5ed35889-e73b-435c-b522-ce26cb3e2ede} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.287052 [ 8184 ] {224c73fc-7569-4a80-a44d-5bb2dea81e36} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[[[[[0x48, 0x65, 0x6c, 0x6c, 0x6f]]]]]], []]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.302107 [ 8184 ] {224c73fc-7569-4a80-a44d-5bb2dea81e36} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.366656 [ 7628 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56516, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:06.372761 [ 7898 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56680, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:06.569762 [ 8184 ] {89d220b7-b49b-4bbd-94f6-fbd28255c7e9} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(Array(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.729967 [ 8184 ] {89d220b7-b49b-4bbd-94f6-fbd28255c7e9} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.808334 [ 8184 ] {eaf5325d-fd78-4fa2-91ce-f3e5a7190608} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[], [['Hello']]]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.818741 [ 8184 ] {eaf5325d-fd78-4fa2-91ce-f3e5a7190608} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.886148 [ 8184 ] {138538bd-f38e-4793-b71f-4197559f10f3} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[['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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.888870 [ 8184 ] {138538bd-f38e-4793-b71f-4197559f10f3} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:06.993653 [ 8184 ] {b243c046-b472-4605-8369-735b05731dd4} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49020) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:07.002925 [ 8184 ] {b243c046-b472-4605-8369-735b05731dd4} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000011e4ae78 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000012f4cf9d 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000012d76a68 7. /build/src/Functions/formatRow.cpp:91: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b1ba08 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&) @ 0x0000000011050d10 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 2025.09.25 21:08:11.172467 [ 5191 ] {1153ff6b-5488-4a5b-a5cd-75755e29c757} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51726) (comment: 00158_cache_dictionary_has.sql) (in query: DROP DICTIONARY IF EXISTS db_dict.cache_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:11.176070 [ 5191 ] {1153ff6b-5488-4a5b-a5cd-75755e29c757} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:11.432395 [ 7897 ] {7c7fa0ad-e8f2-4490-8744-2334a9c96ae3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51760) (comment: 00021_1_select_with_in.sql) (in query: select sum(Sign) from test.visits where CounterID in (942285);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:11.592138 [ 7897 ] {7c7fa0ad-e8f2-4490-8744-2334a9c96ae3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:12.980889 [ 7272 ] {be5e0f23-dfcf-41d3-b0d0-5baf16fdc9b3} executeQuery: Code: 57. DB::Exception: Table test.hits_log already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51814) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_log (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:08:13.093768 [ 7272 ] {be5e0f23-dfcf-41d3-b0d0-5baf16fdc9b3} TCPHandler: Code: 57. DB::Exception: Table test.hits_log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:08:13.936237 [ 7616 ] {269742c4-40f2-41f0-9f8d-a5c618aa9868} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44092) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE positiveModulo(`y`, 3) = 1 GROUP BY `__table1`.`y` ORDER BY `__table1`.`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'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:13.946880 [ 7616 ] {269742c4-40f2-41f0-9f8d-a5c618aa9868} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.077613 [ 7261 ] {703b29f7-3a51-4ad1-bc08-eafe8878c7db} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=729). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51834) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT y, count() FROM 02535_custom_key_rmt_hash 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:14.091338 [ 7261 ] {703b29f7-3a51-4ad1-bc08-eafe8878c7db} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=729). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:14.224575 [ 8458 ] {de14cbad-349e-4804-a4d8-c7cf716012dd} 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]:56672). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56672) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE positiveModulo(`y`, 3) = 2 GROUP BY `__table1`.`y` ORDER BY `__table1`.`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'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbf92f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf64a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.230439 [ 8458 ] {de14cbad-349e-4804-a4d8-c7cf716012dd} 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]:56672). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:14.232276 [ 8458 ] {de14cbad-349e-4804-a4d8-c7cf716012dd} 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]:56672). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbf92f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf64a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.235022 [ 8458 ] {de14cbad-349e-4804-a4d8-c7cf716012dd} TCPHandler: Client has gone away. 2025.09.25 21:08:14.329326 [ 7934 ] {56abd4ab-31ca-46e5-b640-30a51138d471} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56500). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56500) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE positiveModulo(`y`, 3) = 0 GROUP BY `__table1`.`y` ORDER BY `__table1`.`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'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.345786 [ 7934 ] {56abd4ab-31ca-46e5-b640-30a51138d471} 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]:56500). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:14.354539 [ 7934 ] {56abd4ab-31ca-46e5-b640-30a51138d471} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56500). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.369107 [ 7934 ] {56abd4ab-31ca-46e5-b640-30a51138d471} TCPHandler: Client has gone away. 2025.09.25 21:08:14.645343 [ 7622 ] {14ec3944-1482-4e00-a0c7-4c3e619aeea2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51842) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3b03 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a42d6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a3d28 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4032 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*) @ 0x000000001190d697 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:08:14.651420 [ 7622 ] {14ec3944-1482-4e00-a0c7-4c3e619aeea2} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3b03 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a42d6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a3d28 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4032 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*) @ 0x000000001190d697 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:08:15.521583 [ 5600 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57020, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:15.523050 [ 2929 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52128, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:15.883430 [ 8460 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52140, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:15.884141 [ 7261 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57026, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:15.916779 [ 8203 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52152, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:15.919028 [ 8201 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57004, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:16.708636 [ 2926 ] {01600_log_queries_with_extensive_info_018} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38508) (comment: 01600_log_queries_with_extensive_info.sh) (in query: drop database if exists test_log_queries), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:08:16.725251 [ 2926 ] {01600_log_queries_with_extensive_info_018} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:08:18.311583 [ 7937 ] {96211ac9-e30f-454a-ae0c-c9f8679fba78} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column UserID): (while reading from part /var/lib/clickhouse/store/282/2825488e-d0f8-4c85-8067-40ac6226e461/201403_5_5_0/ in table test.visits (2825488e-d0f8-4c85-8067-40ac6226e461) located on disk default of type local, from mark 0 with max_rows_to_read = 38219): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51854) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba405c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5bdb 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2fcff 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 @ 0x0000000010cd58d9 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 2025.09.25 21:08:18.371153 [ 7937 ] {96211ac9-e30f-454a-ae0c-c9f8679fba78} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column UserID): (while reading from part /var/lib/clickhouse/store/282/2825488e-d0f8-4c85-8067-40ac6226e461/201403_5_5_0/ in table test.visits (2825488e-d0f8-4c85-8067-40ac6226e461) located on disk default of type local, from mark 0 with max_rows_to_read = 38219): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba405c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5bdb 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2fcff 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 @ 0x0000000010cd58d9 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 2025.09.25 21:08:18.483127 [ 7599 ] {630a1884-1e59-464c-ba11-57c7fb97b6fb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52524) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT `__table1`.`y` AS `y`, count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` WHERE `y` < 1431655765 GROUP BY `__table1`.`y` ORDER BY `__table1`.`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'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:18.505409 [ 7599 ] {630a1884-1e59-464c-ba11-57c7fb97b6fb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:18.611914 [ 7902 ] {efe4d7ec-ae3b-45ff-bf5f-283ef1015181} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36700) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT y, count() FROM 02535_custom_key_rmt_hash 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:18.616434 [ 7902 ] {efe4d7ec-ae3b-45ff-bf5f-283ef1015181} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:18.617617 [ 7898 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33774, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:19.443497 [ 4649 ] {05a4a5e0-3a66-4644-9e31-3ec58537ed66} executeQuery: Code: 302. DB::Exception: Child process was exited with return code 134: In scope SELECT test_function(2, 2). (CHILD_WAS_NOT_EXITED_NORMALLY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36734) (comment: 02043_user_defined_executable_function_implicit_cast.sql) (in query: SELECT test_function(2, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ShellCommand.cpp:0: DB::ShellCommand::handleProcessRetcode(int) const @ 0x000000000c7bbd69 5. /build/src/Processors/Sources/ShellCommandSource.cpp:514: DB::(anonymous namespace)::ShellCommandSource::prepare() @ 0x000000001307ddb5 6. /build/src/Processors/Executors/ExecutingGraph.cpp:0: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x0000000012d64cb1 7. /build/src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60b5f 8. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 11. /build/src/Functions/UserDefined/UserDefinedExecutableFunctionFactory.cpp:211: DB::(anonymous namespace)::UserDefinedFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013231f5b 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:08:19.475040 [ 4649 ] {05a4a5e0-3a66-4644-9e31-3ec58537ed66} TCPHandler: Code: 302. DB::Exception: Child process was exited with return code 134: In scope SELECT test_function(2, 2). (CHILD_WAS_NOT_EXITED_NORMALLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/ShellCommand.cpp:0: DB::ShellCommand::handleProcessRetcode(int) const @ 0x000000000c7bbd69 5. /build/src/Processors/Sources/ShellCommandSource.cpp:514: DB::(anonymous namespace)::ShellCommandSource::prepare() @ 0x000000001307ddb5 6. /build/src/Processors/Executors/ExecutingGraph.cpp:0: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x0000000012d64cb1 7. /build/src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60b5f 8. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 11. /build/src/Functions/UserDefined/UserDefinedExecutableFunctionFactory.cpp:211: DB::(anonymous namespace)::UserDefinedFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013231f5b 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 23. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 2025.09.25 21:08:19.778332 [ 8461 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36322, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:19.871876 [ 7622 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45320, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:19.883819 [ 7271 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39000, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:19.926564 [ 7934 ] {7269ad90-5d14-4424-afbb-0017561ab827} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45328) (comment: 00009_uniq_distributed.sql) (in query: SELECT uniq(`__table1`.`UserID`) AS `uniq(UserID)`, uniqIf(`__table1`.`UserID`, `__table1`.`CounterID` = 800784) AS `uniqIf(UserID, equals(CounterID, 800784))`, uniqIf(`__table1`.`FUniqID`, `__table1`.`RegionID` = 213) AS `uniqIf(FUniqID, equals(RegionID, 213))` FROM `test`.`hits` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:19.937124 [ 7934 ] {7269ad90-5d14-4424-afbb-0017561ab827} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:20.038809 [ 7901 ] {21601b45-46a0-4848-9a76-f43e7c08a294} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36702) (comment: 00009_uniq_distributed.sql) (in query: SELECT uniq(UserID), uniqIf(UserID, CounterID = 800784), uniqIf(FUniqID, RegionID = 213) FROM remote('127.0.0.{1,2}', test, hits) ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:20.045509 [ 7901 ] {21601b45-46a0-4848-9a76-f43e7c08a294} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:20.058017 [ 7272 ] {748abfa3-3417-40dc-9837-7e6209e3e65d} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:39006). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39006) (comment: 00009_uniq_distributed.sql) (in query: SELECT uniq(`__table1`.`UserID`) AS `uniq(UserID)`, uniqIf(`__table1`.`UserID`, `__table1`.`CounterID` = 800784) AS `uniqIf(UserID, equals(CounterID, 800784))`, uniqIf(`__table1`.`FUniqID`, `__table1`.`RegionID` = 213) AS `uniqIf(FUniqID, equals(RegionID, 213))` FROM `test`.`hits` 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:08:20.060578 [ 7272 ] {748abfa3-3417-40dc-9837-7e6209e3e65d} 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]:39006). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:20.064493 [ 7272 ] {748abfa3-3417-40dc-9837-7e6209e3e65d} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:39006). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:08:20.068442 [ 7272 ] {748abfa3-3417-40dc-9837-7e6209e3e65d} TCPHandler: Client has gone away. 2025.09.25 21:08:22.171884 [ 7626 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36340, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:22.194982 [ 7629 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45350, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:22.570563 [ 8204 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45340, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:22.574802 [ 7935 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39012, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:23.534784 [ 8200 ] {f98a5d22-6513-4020-baac-2df9f8810f64} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51820) (comment: 02765_queries_with_subqueries_profile_events.sh) (in query: SELECT 1 view, 1 enable_analyzer, ProfileEvents['InsertQuery'] InsertQuery, ProfileEvents['SelectQuery'] SelectQuery, ProfileEvents['InsertQueriesWithSubqueries'] InsertQueriesWithSubqueries, -- FIXME: for analyzer it will have one more for sample block ProfileEvents['SelectQueriesWithSubqueries'] SelectQueriesWithSubqueries, ProfileEvents['QueriesWithSubqueries'] QueriesWithSubqueries FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query_id = 'loroncawng' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:23.556517 [ 8200 ] {f98a5d22-6513-4020-baac-2df9f8810f64} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:23.937069 [ 7271 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39024, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:25.951537 [ 7934 ] {01600_log_queries_with_extensive_info_004_err} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36924) (comment: 01600_log_queries_with_extensive_info.sh) (in query: select k from test_log_queries.logtable where i > ''), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000c6cb8bb 5. ? @ 0x0000000010d3400c 6. /build/src/DataTypes/Serializations/SerializationNumber.cpp:34: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010d33e6a 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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 @ 0x0000000008c1e152 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c03ca6 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&, bool&) @ 0x0000000011625c38 21. /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>>&) @ 0x0000000011654949 22. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 26. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 27. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 28. /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&) @ 0x000000001166213c 29. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 30. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 31. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 2025.09.25 21:08:25.988758 [ 7934 ] {01600_log_queries_with_extensive_info_004_err} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000c6cb8bb 5. ? @ 0x0000000010d3400c 6. /build/src/DataTypes/Serializations/SerializationNumber.cpp:34: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010d33e6a 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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 @ 0x0000000008c1e152 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c03ca6 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&, bool&) @ 0x0000000011625c38 21. /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>>&) @ 0x0000000011654949 22. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 26. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 27. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 28. /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&) @ 0x000000001166213c 29. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 30. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 31. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 2025.09.25 21:08:26.573840 [ 7272 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45374, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:26.601326 [ 8200 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39028, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:26.602362 [ 7937 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45366, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:26.962267 [ 7261 ] {01600_log_queries_with_extensive_info_005} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36958) (comment: 01600_log_queries_with_extensive_info.sh) (in query: select k from test_log_queries.logtable where i = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:26.969531 [ 7261 ] {01600_log_queries_with_extensive_info_005} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:28.832665 [ 7896 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:53436, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:28.833587 [ 4649 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43316, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:29.527483 [ 7597 ] {a9403d72-2537-4dba-9103-2299f7d55d72} executeQuery: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42860) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:29.607320 [ 7597 ] {a9403d72-2537-4dba-9103-2299f7d55d72} TCPHandler: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:31.208965 [ 8203 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43322, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:31.834417 [ 8458 ] {57ec974d-8b30-4390-bb73-d67b86fe70c8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42900) (comment: 00010_quantiles_segfault.sql) (in query: SELECT URL AS `ym:ah:URL`, sum((NOT DontCountHits AND NOT Refresh)), quantilesTimingIf(0.1, 0.5, 0.9)((DOMCompleteTiming + LoadEventEndTiming), DOMCompleteTiming != -1 AND LoadEventEndTiming != -1) as t FROM remote('127.0.0.{1,2}', test, hits) WHERE (CounterID = 800784) AND (((DontCountHits = 0) OR (IsNotBounce = 1)) AND (URL != '')) GROUP BY `ym:ah:URL` WITH TOTALS HAVING (sum((NOT DontCountHits AND NOT Refresh)) > 0) AND (count() > 0) ORDER BY sum((NOT DontCountHits AND NOT Refresh)) DESC, URL LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:31.868130 [ 8458 ] {57ec974d-8b30-4390-bb73-d67b86fe70c8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:31.996931 [ 8184 ] {89aa5580-052e-473a-836f-0c46c607bff0} executeQuery: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42926) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:32.006722 [ 8184 ] {89aa5580-052e-473a-836f-0c46c607bff0} TCPHandler: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:32.403603 [ 11261 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:53442, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:32.546196 [ 11261 ] {2e6823f8-ef91-4876-89eb-c9e848fc5866} executeQuery: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42948) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:32.551702 [ 11261 ] {2e6823f8-ef91-4876-89eb-c9e848fc5866} TCPHandler: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:34.267629 [ 11262 ] {a900bb89-b333-45b8-9f0a-aa4143141990} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42982) (comment: 00045_uniq_upto.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM test.visits GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:34.523299 [ 11262 ] {a900bb89-b333-45b8-9f0a-aa4143141990} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:08:34.660750 [ 7600 ] {26999e30-552a-4743-b914-13640a2165c2} executeQuery: Code: 497. DB::Exception: user02884_3_test_3_16553: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43012) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:34.679534 [ 7600 ] {26999e30-552a-4743-b914-13640a2165c2} TCPHandler: Code: 497. DB::Exception: user02884_3_test_3_16553: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:35.708414 [ 11261 ] {5965b7ac-5006-4ce3-a2fb-2538de8cc5a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43034) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT count() FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:35.723982 [ 11261 ] {5965b7ac-5006-4ce3-a2fb-2538de8cc5a0} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:35.919857 [ 7627 ] {bb28578e-3d40-46bf-ad4e-27803926632c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42902) (comment: 00674_join_on_syntax.sql) (in query: select a1, b1 from tab1 any left join tab2 on b1 = a2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:35.925883 [ 7627 ] {bb28578e-3d40-46bf-ad4e-27803926632c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:36.187047 [ 7260 ] {cf159aee-15b1-4708-b3ad-b41043a4d314} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36910) (comment: 02765_queries_with_subqueries_profile_events.sh) (in query: SELECT 1 subquery, 1 enable_analyzer, ProfileEvents['InsertQuery'] InsertQuery, ProfileEvents['SelectQuery'] SelectQuery, ProfileEvents['InsertQueriesWithSubqueries'] InsertQueriesWithSubqueries, ProfileEvents['SelectQueriesWithSubqueries'] SelectQueriesWithSubqueries, ProfileEvents['QueriesWithSubqueries'] QueriesWithSubqueries FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query_id = 'rbhuxxpzyi' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:36.229898 [ 7260 ] {cf159aee-15b1-4708-b3ad-b41043a4d314} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:37.513628 [ 5795 ] {9e328a39-8483-4b8b-b7d0-5870c2e11d23} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38996) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT count() AS `count()` FROM `test_13`.`02535_custom_key_rmt_hash` AS `__table1` ALL INNER JOIN `test_13`.`02535_custom_key_rmt_hash` AS `__table2` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:37.525225 [ 5795 ] {9e328a39-8483-4b8b-b7d0-5870c2e11d23} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:08:37.565254 [ 7607 ] {89a9e569-a794-4f75-a228-a06591c0b3e0} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43078) (comment: 02535_max_parallel_replicas_custom_key_rmt.sh) (in query: SELECT count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_rmt_hash) as t1 JOIN 02535_custom_key_rmt_hash 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:37.575642 [ 7607 ] {89a9e569-a794-4f75-a228-a06591c0b3e0} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:08:38.024285 [ 7615 ] {8a09d52b-031d-46d6-9a2a-33c10156ccc5} executeQuery: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41888) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_view_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:38.056510 [ 7615 ] {8a09d52b-031d-46d6-9a2a-33c10156ccc5} TCPHandler: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 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) @ 0x0000000011665e7d 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&) @ 0x000000001166213c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 17. /build/src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001164866d 18. /build/src/Storages/StorageView.cpp:0: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000124d5b4d 19. /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) @ 0x000000001166839f 20. /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&) @ 0x000000001166213c 21. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:08:39.859076 [ 4265 ] {735856bc-dfc3-49fa-a952-5da37146c8b6} executeQuery: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41942) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE MATERIALIZED VIEW test_3.test_mv_2 (s String) ENGINE = MergeTree ORDER BY s SQL SECURITY INVOKER AS SELECT * FROM test_3.test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageMaterializedView.cpp:102: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000122ebe80 5. /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&) @ 0x00000000122f3667 6. /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&) @ 0x00000000122f28cb 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:08:39.890724 [ 4265 ] {735856bc-dfc3-49fa-a952-5da37146c8b6} TCPHandler: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageMaterializedView.cpp:102: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000122ebe80 5. /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&) @ 0x00000000122f3667 6. /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&) @ 0x00000000122f28cb 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:08:40.518060 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {53303125-9975-4221-b621-bca733688e45::202509_1_30_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:40.926012 [ 7640 ] {8f3edf8a-d704-48ed-971c-b22ce591d463} 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]:43332). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43332) (comment: 00010_quantiles_segfault.sql) (in query: SELECT `__table1`.`URL` AS `ym:ah:URL`, sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) AS `sum(and(not(DontCountHits), not(Refresh)))`, quantilesTimingIf(0.1, 0.5, 0.9)(`__table1`.`DOMCompleteTiming` + `__table1`.`LoadEventEndTiming`, (`__table1`.`DOMCompleteTiming` != -1) AND (`__table1`.`LoadEventEndTiming` != -1)) AS `t` FROM `test`.`hits` AS `__table1` WHERE (`__table1`.`CounterID` = 800784) AND (((`__table1`.`DontCountHits` = 0) OR (`__table1`.`IsNotBounce` = 1)) AND (`__table1`.`URL` != '')) GROUP BY `__table1`.`URL` WITH TOTALS HAVING (sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) > 0) AND (count() > 0) ORDER BY sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) DESC, `__table1`.`URL` ASC LIMIT _CAST(0, 'UInt64'), _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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:40.927420 [ 4992 ] {ca3edd5f-0391-47b3-9268-29812f2400c8} 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]:53440). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53440) (comment: 00010_quantiles_segfault.sql) (in query: SELECT `__table1`.`URL` AS `ym:ah:URL`, sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) AS `sum(and(not(DontCountHits), not(Refresh)))`, quantilesTimingIf(0.1, 0.5, 0.9)(`__table1`.`DOMCompleteTiming` + `__table1`.`LoadEventEndTiming`, (`__table1`.`DOMCompleteTiming` != -1) AND (`__table1`.`LoadEventEndTiming` != -1)) AS `t` FROM `test`.`hits` AS `__table1` WHERE (`__table1`.`CounterID` = 800784) AND (((`__table1`.`DontCountHits` = 0) OR (`__table1`.`IsNotBounce` = 1)) AND (`__table1`.`URL` != '')) GROUP BY `__table1`.`URL` WITH TOTALS HAVING (sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) > 0) AND (count() > 0) ORDER BY sum((NOT `__table1`.`DontCountHits`) AND (NOT `__table1`.`Refresh`)) DESC, `__table1`.`URL` ASC LIMIT _CAST(0, 'UInt64'), _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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:40.934298 [ 7640 ] {8f3edf8a-d704-48ed-971c-b22ce591d463} 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]:43332). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:40.942182 [ 7640 ] {8f3edf8a-d704-48ed-971c-b22ce591d463} 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]:43332). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:40.945884 [ 4992 ] {ca3edd5f-0391-47b3-9268-29812f2400c8} 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]:53440). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:40.956824 [ 7640 ] {8f3edf8a-d704-48ed-971c-b22ce591d463} TCPHandler: Client has gone away. 2025.09.25 21:08:40.960569 [ 4992 ] {ca3edd5f-0391-47b3-9268-29812f2400c8} 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]:53440). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:08:40.972973 [ 4992 ] {ca3edd5f-0391-47b3-9268-29812f2400c8} TCPHandler: Client has gone away. 2025.09.25 21:08:41.058386 [ 4265 ] {8b0a7fab-d55a-4458-9465-327009355411} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41968) (comment: 02990_arrayFold_nullable_lc.sql) (in query: SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], materialize(toInt64(toNullable(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:41.061064 [ 4265 ] {8b0a7fab-d55a-4458-9465-327009355411} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:41.899600 [ 4245 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000011170f2f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159ac1 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&) @ 0x0000000010dfb98a 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:42.015167 [ 7898 ] {20a609e7-b0c4-43e0-b88b-d2e2986000e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41990) (comment: 00174_distinct_in_order.sql) (in query: select '-- DISTINCT columns are the same as in ORDER BY';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:42.016571 [ 4296 ] {} DDLWorker(test_w8n5ho07): Error on initialization of test_w8n5ho07: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_w8n5ho07' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000011170f2f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159ac1 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&) @ 0x0000000010dfb98a 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10508.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::DatabaseReplicated::waitDatabaseStarted() const @ 0x0000000010de101e 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010de9f99 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e054d4 8. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e037e8 9. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x0000000011159e71 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111710a2 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:42.020800 [ 7898 ] {20a609e7-b0c4-43e0-b88b-d2e2986000e4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:42.121306 [ 7607 ] {8b3beb4e-0118-4a17-abc6-4ea4a665ca22} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02461_mullable_pk_monotonicity_bug.sql) (in query: /* ddl_entry=query-0000000027 */ CREATE TABLE test_5.tab UUID '9e2334a1-a45c-48e2-8edd-34b0bfb2db7c' (`x` LowCardinality(UInt8)) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 2, min_bytes_for_wide_part = 993570204, ratio_of_defaults_for_sparse_serialization = 0.07302559912204742, 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 = 294092453, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25746948, merge_max_block_size = 2913, old_parts_lifetime = 354., prefer_fetch_merged_part_size_threshold = 2765346136, vertical_merge_algorithm_min_rows_to_activate = 674912, vertical_merge_algorithm_min_columns_to_activate = 85, min_merge_bytes_to_use_direct_io = 2813719686, index_granularity_bytes = 20478853, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 27182, primary_key_compress_block_size = 62960), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:08:42.163535 [ 7607 ] {8b3beb4e-0118-4a17-abc6-4ea4a665ca22} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41876) (comment: 02461_mullable_pk_monotonicity_bug.sql) (in query: CREATE TABLE tab (`x` LowCardinality(UInt8)) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 2, min_bytes_for_wide_part = 993570204, ratio_of_defaults_for_sparse_serialization = 0.07302559912204742, 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 = 294092453, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25746948, merge_max_block_size = 2913, old_parts_lifetime = 354., prefer_fetch_merged_part_size_threshold = 2765346136, vertical_merge_algorithm_min_rows_to_activate = 674912, vertical_merge_algorithm_min_columns_to_activate = 85, min_merge_bytes_to_use_direct_io = 2813719686, index_granularity_bytes = 20478853, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 27182, primary_key_compress_block_size = 62960), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:08:42.170197 [ 7607 ] {8b3beb4e-0118-4a17-abc6-4ea4a665ca22} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:08:44.265509 [ 7604 ] {eaa35241-a88d-4cab-bf56-3d35383710bd} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.081972003 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45468) (comment: 02293_http_header_summary_contains_exception_code_with_progress.sh) (in query: SELECT 1 + sleepEachRow(0.00002) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:44.269611 [ 7604 ] {eaa35241-a88d-4cab-bf56-3d35383710bd} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.081972003 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:45.211856 [ 7607 ] {3fabeb96-c7c4-4f17-9286-cd4b05b850f1} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 18446744073709551615. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10508.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42118) (comment: 02424_pod_array_overflow.sql) (in query: SELECT * FROM format(Native, '\x02\x02\x02\x6b\x30\x1a\x4d\x61\x70\x28\x46\x69\x78\x65\x64\x53\x74\x72\x69\x6e\x67\x28\x31\x29\x2c\x20\x49\x6e\x74\x36\x34\x29\x01\x00\x00\x00\x00\x00\x00\x00\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\xff\x7f\x00\x7f\xff\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x64\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\x00\xcf\x31\x3f\x56\x69\x11\x89\x25');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000012d2cd1a 5. /build/src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000012d2db22 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a22bd 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 8. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:45.220104 [ 7607 ] {3fabeb96-c7c4-4f17-9286-cd4b05b850f1} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 18446744073709551615. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10508.altinitytest (altinity build)). You can specify the 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000012d2cd1a 5. /build/src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000012d2db22 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a22bd 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 8. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.057810 [ 7898 ] {36e835bd-7241-4de0-bacf-d94d6a29791e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42052) (comment: 02458_datediff_date32.sql) (in query: SELECT dateDiff('year', toDateTime64('1927-01-01 00:00:00', 3, 'UTC'), toDate32('1928-01-01', 'UTC'), '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.077940 [ 7898 ] {36e835bd-7241-4de0-bacf-d94d6a29791e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.095070 [ 7615 ] {48c56dc3-3f41-4582-8861-48e7ad932a3e} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_w8n5ho07' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000011170f2f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159ac1 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&) @ 0x0000000010dfb98a 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10508.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45588) (comment: 00034_aggregate_key_fixed_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_w8n5ho07 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001154afd4 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.111547 [ 7615 ] {48c56dc3-3f41-4582-8861-48e7ad932a3e} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_w8n5ho07' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000011170f2f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159ac1 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&) @ 0x0000000010dfb98a 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10508.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001154afd4 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:47.297278 [ 7607 ] {ec9998b5-2e4e-4e75-a255-0c0f1046d181} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:a7c1f9a3-d6fd-4cca-b958-76a2ef0932a3'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56944) (comment: 00044_any_left_join_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_f9os439k ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.313495 [ 7607 ] {ec9998b5-2e4e-4e75-a255-0c0f1046d181} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:a7c1f9a3-d6fd-4cca-b958-76a2ef0932a3'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:47.466787 [ 5310 ] {67347062-2aa6-42a8-ae9c-8e8b8995b864} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e00a18a6-6aba-4197-941f-1814f87db38a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56948) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE DATABASE IF NOT EXISTS test_02nj5czc ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.481329 [ 5310 ] {67347062-2aa6-42a8-ae9c-8e8b8995b864} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e00a18a6-6aba-4197-941f-1814f87db38a'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:47.628386 [ 8473 ] {3dd3970b-f958-4ba4-9be7-8b27d19d8f9f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e113a817-3157-4f21-8cf6-c9defdf10469'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56954) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE DATABASE IF NOT EXISTS test_1thfuuis ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.633478 [ 8473 ] {3dd3970b-f958-4ba4-9be7-8b27d19d8f9f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e113a817-3157-4f21-8cf6-c9defdf10469'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:47.753406 [ 5310 ] {d01db131-9ee1-461e-bd99-927d69e7cd71} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e8d64315-e0fc-4c63-bc8e-3887c7fa003e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56960) (comment: 00159_parallel_formatting_json_and_friends_1.sh) (in query: CREATE DATABASE IF NOT EXISTS test_k3np4ld7 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.767077 [ 5310 ] {d01db131-9ee1-461e-bd99-927d69e7cd71} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:e8d64315-e0fc-4c63-bc8e-3887c7fa003e'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:47.924892 [ 7607 ] {9970fb84-0759-4051-a74b-e835ef424501} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:19d05b31-ce71-4408-b5c5-4517b56ec49e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56964) (comment: 00148_monotonic_functions_and_index.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zj1beuyk ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:47.928636 [ 7607 ] {9970fb84-0759-4051-a74b-e835ef424501} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:19d05b31-ce71-4408-b5c5-4517b56ec49e'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.028536 [ 8178 ] {0d30a824-980d-4375-ae74-5d80ebf781f8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:f83ac160-c5e7-4f2a-9373-ecb2018d87d6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56970) (comment: 00047_bar.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rir9wlqp ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.035465 [ 8178 ] {0d30a824-980d-4375-ae74-5d80ebf781f8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:f83ac160-c5e7-4f2a-9373-ecb2018d87d6'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.141001 [ 7607 ] {909f0b74-d0f5-4271-af36-d3c9854f411a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:c600ca87-697d-4b1f-98f7-7a115b6f85b6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56984) (comment: 00041_aggregating_materialized_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7h6q13p6 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.148639 [ 7607 ] {909f0b74-d0f5-4271-af36-d3c9854f411a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:c600ca87-697d-4b1f-98f7-7a115b6f85b6'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.249341 [ 8473 ] {7bd1dfe0-50d9-4a02-b2d0-5e646840373a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:69969c25-2d41-439b-9dbd-6dea0b87e1e4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56996) (comment: 00083_array_filter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_375zgupo ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.252784 [ 8473 ] {7bd1dfe0-50d9-4a02-b2d0-5e646840373a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:69969c25-2d41-439b-9dbd-6dea0b87e1e4'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.451812 [ 8473 ] {48015f42-0c6b-4a6d-b6d9-ffa1afa23de3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:7ae067c8-31bb-4124-a6dc-4b07ed408e9f'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56998) (comment: 00159_parallel_formatting_csv_and_friends.sh) (in query: CREATE DATABASE IF NOT EXISTS test_4gv7ydva ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.454420 [ 8473 ] {48015f42-0c6b-4a6d-b6d9-ffa1afa23de3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:7ae067c8-31bb-4124-a6dc-4b07ed408e9f'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.558216 [ 7604 ] {59c49028-c53a-4ae8-a072-374a29b2c05d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:7a80b3a7-9ecb-4a9a-99fb-dd7bf8b02093'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57006) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0am3y5st ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.562999 [ 7604 ] {59c49028-c53a-4ae8-a072-374a29b2c05d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:7a80b3a7-9ecb-4a9a-99fb-dd7bf8b02093'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.624731 [ 7607 ] {efec035e-9518-4817-99b5-6f19e1f43a67} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:6d3f686f-2668-4f0b-8a82-f03015ed5401'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57018) (comment: 00069_duplicate_aggregation_keys.sql) (in query: CREATE DATABASE IF NOT EXISTS test_r1rh42xg ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.628257 [ 7607 ] {efec035e-9518-4817-99b5-6f19e1f43a67} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:6d3f686f-2668-4f0b-8a82-f03015ed5401'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.691036 [ 8473 ] {ac983d8e-ee46-4b7a-9702-61e49d5e62d5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:9fec85dc-afce-4265-82c3-b89bdf8998ca'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57028) (comment: 00036_aggregate_hashed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ohlq4b3n ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.695695 [ 8473 ] {ac983d8e-ee46-4b7a-9702-61e49d5e62d5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:9fec85dc-afce-4265-82c3-b89bdf8998ca'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.763559 [ 8178 ] {79b39c3b-b22e-44de-afdf-44d08ab110d8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:79770fa0-35a3-40fd-9edd-62b0ff6840ef'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57030) (comment: 00159_parallel_formatting_http.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2g1gf9fl ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.777137 [ 8178 ] {79b39c3b-b22e-44de-afdf-44d08ab110d8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:79770fa0-35a3-40fd-9edd-62b0ff6840ef'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:48.779975 [ 7604 ] {19af9d8d-8143-4581-9be7-c479024120e4} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_mv_data. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37846) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_mv_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122ed0d7 11. /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) @ 0x000000001166839f 12. /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&) @ 0x000000001166213c 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 15. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 16. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.803997 [ 7604 ] {19af9d8d-8143-4581-9be7-c479024120e4} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_mv_data. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122ed0d7 11. /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) @ 0x000000001166839f 12. /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&) @ 0x000000001166213c 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 15. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 16. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:08:48.991798 [ 8473 ] {bdc26b78-f7b0-4925-b405-ef18148c143d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:9771c95f-5ba1-40b1-a817-afa1a359638f'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57046) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: CREATE DATABASE IF NOT EXISTS test_8r0ujeyg ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.054103 [ 8473 ] {bdc26b78-f7b0-4925-b405-ef18148c143d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:9771c95f-5ba1-40b1-a817-afa1a359638f'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:49.124813 [ 2929 ] {5b078946-4898-4721-99d5-eaed76f3f1dd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:28aa912b-0caf-4738-b0ac-2d0045ebe200'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57052) (comment: 00065_loyalty_with_storage_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ulkb1k18 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.209243 [ 2929 ] {5b078946-4898-4721-99d5-eaed76f3f1dd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:28aa912b-0caf-4738-b0ac-2d0045ebe200'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:49.253906 [ 4265 ] {64349bba-5870-4820-9ae7-1e15198da7c4} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42162) (comment: 03210_dynamic_squashing.sql) (in query: CREATE TABLE test (`d` Dynamic(max_types = 1)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 4771, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 5884448, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 11899976, merge_max_block_size = 13183, old_parts_lifetime = 41., 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 = 1, index_granularity_bytes = 1487487, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 51276, primary_key_compress_block_size = 20113), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.261204 [ 4265 ] {64349bba-5870-4820-9ae7-1e15198da7c4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.300369 [ 7902 ] {a4466632-0370-4513-af51-c719d99489d6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:a4ecfc64-bc27-4d62-960b-398e7132c9e8'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57058) (comment: 00016_any_if_distributed_cond_always_false.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1iry9yb0 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.312779 [ 7902 ] {a4466632-0370-4513-af51-c719d99489d6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:a4ecfc64-bc27-4d62-960b-398e7132c9e8'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:49.377377 [ 8473 ] {df0ee859-9aca-48dd-bd1e-8ad675f8c031} PushingToViews: Failed to push block to view test_3.test_mv_4 (a5d0bd1d-1d7a-443f-936a-adcc58db0d75), user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_3.test_mv_data 2025.09.25 21:08:49.423406 [ 2929 ] {300e53b9-ce1f-4e96-ac70-15465e1be11c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:c976f7b4-c98d-4484-8df2-c29dab8313f5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57072) (comment: 00086_array_reduce.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gwce1re6 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.439344 [ 2929 ] {300e53b9-ce1f-4e96-ac70-15465e1be11c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:c976f7b4-c98d-4484-8df2-c29dab8313f5'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:49.590114 [ 8473 ] {df0ee859-9aca-48dd-bd1e-8ad675f8c031} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_3.test_mv_data. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37874) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_3.test_table 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x00000000115f601f 11. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x00000000130528b2 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001305486a 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa0e7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb861 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.592192 [ 7902 ] {45e9d028-6f8b-4970-98e8-b32d6f24ced9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:038a1e18-7faf-40ab-a1df-98dd721db3e5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57082) (comment: 00167_read_bytes_from_fs.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0dqhxdr4 ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.609623 [ 7902 ] {45e9d028-6f8b-4970-98e8-b32d6f24ced9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:038a1e18-7faf-40ab-a1df-98dd721db3e5'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:49.629537 [ 8473 ] {df0ee859-9aca-48dd-bd1e-8ad675f8c031} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_3.test_mv_data. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x00000000115f601f 11. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x00000000130528b2 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001305486a 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa0e7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb861 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.787376 [ 2929 ] {3ac89d35-f0a6-4d6e-b8bb-9e44693b7574} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:1d9fed87-74b7-4503-8bf8-4c654ee5bc69'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57094) (comment: 00140_rename.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tptqlq6d ENGINE=Replicated('/test/db/test_14', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:08:49.796472 [ 2929 ] {3ac89d35-f0a6-4d6e-b8bb-9e44693b7574} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'f386c69fe321:9000:9f8e1685-7bda-47f2-a6cd-576075879a02', current host ID: 'f386c69fe321:9000:1d9fed87-74b7-4503-8bf8-4c654ee5bc69'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010dfc879 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddc770 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010ddfff4 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a4a1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154ae60 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:50.325378 [ 7598 ] {ac1b3017-ef12-4337-b989-d3bcb56965f8} PushingToViews: Failed to push block to view test_3.test_mv_4 (a5d0bd1d-1d7a-443f-936a-adcc58db0d75), user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_3.test_mv_data 2025.09.25 21:08:52.506581 [ 2929 ] {455e1e12-558f-49cc-9a66-8648a4de4ba6} 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.10508.altinitytest (altinity build)) (from [::1]:57096) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_ico5ip88 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:08:52.513772 [ 2929 ] {455e1e12-558f-49cc-9a66-8648a4de4ba6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:08:57.263033 [ 2929 ] {cfa7e67b-7ebf-4aae-9b15-e45d58c3b733} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37392) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_3.test_mv_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122ecf62 11. /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) @ 0x000000001166839f 12. /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&) @ 0x000000001166213c 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 15. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 16. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:08:57.296838 [ 2929 ] {cfa7e67b-7ebf-4aae-9b15-e45d58c3b733} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122ecf62 11. /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) @ 0x000000001166839f 12. /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&) @ 0x000000001166213c 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 15. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 16. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:08:57.836443 [ 7598 ] {e36b989e-32c2-41c8-b4f9-63f3bcc30403} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37998) (comment: 01251_dict_is_in_infinite_loop.sql) (in query: SELECT dictIsIn('database_for_dict.dictionary_with_hierarchy', materialize(toUInt64(22)), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:57.846390 [ 7598 ] {e36b989e-32c2-41c8-b4f9-63f3bcc30403} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:08:58.069433 [ 2929 ] {01d1f8c1-0635-4395-83b7-4ca7a2f6802b} PushingToViews: Failed to push block to view test_3.test_mv_4 (a5d0bd1d-1d7a-443f-936a-adcc58db0d75), user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table 2025.09.25 21:08:58.332283 [ 2929 ] {01d1f8c1-0635-4395-83b7-4ca7a2f6802b} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37420) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_3.test_table 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 13. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011647fe5 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000013051236 16. /build/contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001305486a 17. /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*) @ 0x00000000115f67ce 18. /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&) @ 0x00000000115f72f5 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa0e7 20. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb861 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:08:58.367772 [ 2929 ] {01d1f8c1-0635-4395-83b7-4ca7a2f6802b} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_3.test_table. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000011660e93 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 13. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011647fe5 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000013051236 16. /build/contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001305486a 17. /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*) @ 0x00000000115f67ce 18. /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&) @ 0x00000000115f72f5 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa0e7 20. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb861 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:08:59.005850 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {06e0dcf3-6e7a-4ddb-850b-40d5fef4d059::202509_1_41_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:00.651618 [ 4057 ] {2c125ff9-0afb-4d4d-9663-0ad9b5b9dcb2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60570) (comment: 00688_low_cardinality_in.sql) (in query: SELECT `__table1`.`val` AS `val`, `__table1`.`val` IN (1, 3) AS `in(val, (1, 3))` FROM `test_mxr99lr0`.`lc_00688` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:09:00.674314 [ 4057 ] {2c125ff9-0afb-4d4d-9663-0ad9b5b9dcb2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:09:00.815840 [ 7937 ] {8204a4e2-e81e-4d71-826c-d40caf64acc1} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37440) (comment: 00688_low_cardinality_in.sql) (in query: select val, val in (1, 3) from lc_00688;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:00.823018 [ 7937 ] {8204a4e2-e81e-4d71-826c-d40caf64acc1} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:00.915784 [ 7622 ] {880c83ba-5c33-4c4c-b965-557c5bb2bf2c} executeQuery: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_3.source. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37462) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO source SELECT * FROM generateRandom() LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb6e9 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:00.937858 [ 7622 ] {880c83ba-5c33-4c4c-b965-557c5bb2bf2c} TCPHandler: Code: 497. DB::Exception: user02884_2_test_3_9930: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_3.source. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x00000000107e2444 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 @ 0x00000000107e209a 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 @ 0x00000000107e1785 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 @ 0x00000000107c5bc6 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 @ 0x0000000011104e1a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1b69 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb6e9 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:01.025350 [ 7909 ] {4b7bdc2d-a802-43cf-ab21-0a0e7478a2d8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47886) (comment: 00688_low_cardinality_in.sql) (in query: DROP DATABASE IF EXISTS test_mxr99lr0 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:01.101064 [ 7909 ] {4b7bdc2d-a802-43cf-ab21-0a0e7478a2d8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:03.598391 [ 7909 ] {caa09a0f-eb65-4e4c-8094-41247d148822} executeQuery: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37556) (comment: 02884_create_view_with_sql_security_option.sh) (in query: ALTER TABLE test_table MODIFY SQL SECURITY INVOKER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a62a1 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:09:03.610284 [ 7909 ] {caa09a0f-eb65-4e4c-8094-41247d148822} TCPHandler: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a62a1 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:09:05.552061 [ 7934 ] {ce8b138b-269b-401c-9f74-be45fd3cb372} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_3_9930. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37676) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_3.test_view_g_2 DEFINER = user02884_2_test_3_9930 AS SELECT * FROM test_3.test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dbb76 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107db7ed 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000107daee5 7. /build/src/Access/ContextAccess.cpp:824: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000107c593e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000110e1476 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000011559f19 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555732 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:05.583693 [ 7934 ] {ce8b138b-269b-401c-9f74-be45fd3cb372} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_3_9930. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dbb76 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107db7ed 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000107daee5 7. /build/src/Access/ContextAccess.cpp:824: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000107c593e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x00000000110e1476 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000011559f19 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555732 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:05.863740 [ 5220 ] {9afd2835-82ab-4a24-aebd-9d2b79c5ab20} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38048) (comment: 01825_new_type_json_12.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(`__table1`.`obj`)) AS `path` FROM `test_1h6g49o6`.`t_json_12` AS `__table1` ORDER BY arrayJoin(JSONAllPathsWithTypes(`__table1`.`obj`)) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 22. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 23. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 24. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 25. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 26. /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>>&) @ 0x00000000128f70a6 27. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 28. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 29. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 30. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 31. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 2025.09.25 21:09:05.878449 [ 5220 ] {9afd2835-82ab-4a24-aebd-9d2b79c5ab20} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 22. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 23. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 24. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 25. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 26. /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>>&) @ 0x00000000128f70a6 27. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 28. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 29. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 30. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 31. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 2025.09.25 21:09:05.894529 [ 7598 ] {499d3adf-2fd5-4eb7-bcf3-a8d5aa018e05} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 22. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 23. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 24. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 25. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 26. /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>>&) @ 0x00000000128f70a6 27. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 28. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 29. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 30. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 31. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37658) (comment: 01825_new_type_json_12.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(obj)) as path FROM t_json_12 order by path;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:05.897696 [ 7598 ] {499d3adf-2fd5-4eb7-bcf3-a8d5aa018e05} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 20. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cdea11 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d7b511 22. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf303e 23. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 24. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 25. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 26. /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>>&) @ 0x00000000128f70a6 27. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 28. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 29. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 30. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 31. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:06.846041 [ 7934 ] {55d16b37-046f-4afc-b98e-e876a34e079b} executeQuery: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53138) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_3.test_view_g_3 SQL SECURITY NONE AS SELECT * FROM test_3.test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107da184 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000107d9dd0 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d9494 7. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000011559f74 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555732 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:06.869579 [ 7934 ] {55d16b37-046f-4afc-b98e-e876a34e079b} TCPHandler: Code: 497. DB::Exception: user02884_1_test_3_2777: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107da184 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000107d9dd0 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d9494 7. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x0000000011559f74 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555732 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:07.148302 [ 3967 ] {e7b90e8f-43ff-4099-b261-e57e15bd4022} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj.key_0.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39090) (comment: 01825_new_type_json_12.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(`__table1`.`obj.key_0.:\`Array(JSON)\``))) AS `path` FROM `test_1h6g49o6`.`t_json_12` AS `__table1` ORDER BY arrayJoin(JSONAllPathsWithTypes(arrayJoin(`__table1`.`obj.key_0.:\`Array(JSON)\``))) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 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&) @ 0x00000000128f89de 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 @ 0x0000000010cdf741 14. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:0: DB::SerializationVariantElement::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 @ 0x0000000010d8a1b7 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamicElement::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 @ 0x0000000010d01723 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObjectDynamicPath::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 @ 0x0000000010d5d6cd 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:09:07.170894 [ 3967 ] {e7b90e8f-43ff-4099-b261-e57e15bd4022} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj.key_0.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 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&) @ 0x00000000128f89de 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 @ 0x0000000010cdf741 14. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:0: DB::SerializationVariantElement::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 @ 0x0000000010d8a1b7 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamicElement::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 @ 0x0000000010d01723 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObjectDynamicPath::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 @ 0x0000000010d5d6cd 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:09:07.186481 [ 5326 ] {6c80619a-6eee-48ae-9fe6-3cd29ad37113} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj.key_0.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 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&) @ 0x00000000128f89de 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 @ 0x0000000010cdf741 14. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:0: DB::SerializationVariantElement::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 @ 0x0000000010d8a1b7 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamicElement::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 @ 0x0000000010d01723 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObjectDynamicPath::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 @ 0x0000000010d5d6cd 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37710) (comment: 01825_new_type_json_12.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(obj.key_0[]))) as path FROM t_json_12 order by path;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:07.205827 [ 5326 ] {6c80619a-6eee-48ae-9fe6-3cd29ad37113} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): (while reading column obj.key_0.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 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&) @ 0x00000000128f89de 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 @ 0x0000000010cdf741 14. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:0: DB::SerializationVariantElement::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 @ 0x0000000010d8a1b7 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamicElement::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 @ 0x0000000010d01723 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObjectDynamicPath::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 @ 0x0000000010d5d6cd 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) @ 0x00000000128f7914 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:07.278854 [ 5310 ] {095845d3-ad83-4800-943f-b0644e702d0b} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37832) (comment: 01289_min_execution_speed_not_too_early.sql) (in query: SET max_execution_time = 100, timeout_before_checking_execution_speed = 100, max_execution_speed = 1000000, max_threads = 1, max_block_size = 1000000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:07.294295 [ 5310 ] {095845d3-ad83-4800-943f-b0644e702d0b} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:07.864563 [ 8202 ] {6da6056a-90f5-4509-8905-b3133e7d91e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53148) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:09:07.877201 [ 8202 ] {6da6056a-90f5-4509-8905-b3133e7d91e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:09:10.543308 [ 4984 ] {22ce72ed-f8fb-4a11-bb30-66ce7ba0f35e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36902) (comment: 01825_new_type_json_12.sh) (in query: SELECT `__table1`.`obj` AS `obj` FROM `test_1h6g49o6`.`t_json_12` AS `__table1` ORDER BY `__table1`.`obj.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 17. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:09:10.550268 [ 4984 ] {22ce72ed-f8fb-4a11-bb30-66ce7ba0f35e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 17. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:09:10.624226 [ 5326 ] {53c32631-8b1c-40b8-8ba4-95aae3c4d3b2} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 17. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53266) (comment: 01825_new_type_json_12.sh) (in query: SELECT obj FROM t_json_12 ORDER BY obj.id 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:10.630481 [ 5326 ] {53c32631-8b1c-40b8-8ba4-95aae3c4d3b2} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): (while reading column obj): (while reading from part /var/lib/clickhouse/store/6b2/6b2f196f-eeed-4c45-a149-e265b9d90e58/all_1_1_0/ in table test_1h6g49o6.t_json_12 (6b2f196f-eeed-4c45-a149-e265b9d90e58) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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>>>&) @ 0x00000000128f828c 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:337: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8703 13. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000010cf3591 14. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010cf2ce8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d3eb96 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000128f8477 17. /build/contrib/llvm-project/libcxx/include/new:246: 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) @ 0x00000000128f784b 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>>&) @ 0x00000000128f70a6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2b8f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:12.358621 [ 7936 ] {962270c0-ad8c-4d3e-97b8-50182a42d241} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53326) (comment: 01014_lazy_database_basic.sh) (in query: DROP DATABASE testlazy;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:12.400786 [ 7936 ] {962270c0-ad8c-4d3e-97b8-50182a42d241} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:13.478512 [ 7937 ] {a3fee257-d33e-4db9-a771-4317a2666e00} 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.10508.altinitytest (altinity build)) (from [::1]:50832) (comment: 01825_new_type_json_12.sh) (in query: DROP DATABASE IF EXISTS test_1h6g49o6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:13.489567 [ 7937 ] {a3fee257-d33e-4db9-a771-4317a2666e00} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:14.237190 [ 7901 ] {90cbd74c-6ce8-48d1-bfbe-0740d73a0d37} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53300) (comment: 00915_simple_aggregate_function.sql) (in query: optimize table simple 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000012aacaf9 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac0f1 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) @ 0x0000000012a81ced 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) @ 0x0000000012a8734b 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957c4f 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:14.252500 [ 7901 ] {90cbd74c-6ce8-48d1-bfbe-0740d73a0d37} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000012aacaf9 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac0f1 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) @ 0x0000000012a81ced 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) @ 0x0000000012a8734b 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957c4f 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:16.275992 [ 3594 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1f5dde2e-b2d7-4e9d-9554-6a73596d18e1::202509_85_95_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:17.636976 [ 4904 ] {79080f31-db45-43fa-a87a-98dae2711900} 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.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38634) (comment: 00953_moving_functions.sql) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`v` AS `v` FROM `test_n9nl28ul`.`moving_sum_num` AS `__table1` ORDER BY `__table1`.`k` ASC, `__table1`.`dt` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:09:17.643191 [ 4904 ] {79080f31-db45-43fa-a87a-98dae2711900} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:09:17.749064 [ 8202 ] {2241279f-95c9-4a25-8b4b-a1021ee95ab6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38782) (comment: 00953_moving_functions.sql) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`v` AS `v` FROM `test_n9nl28ul`.`moving_sum_num` AS `__table1` ORDER BY `__table1`.`k` ASC, `__table1`.`dt` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:09:17.753155 [ 8202 ] {2241279f-95c9-4a25-8b4b-a1021ee95ab6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:09:17.781078 [ 5326 ] {603e6193-1eed-4511-978c-8509ba8e65a5} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53376) (comment: 00953_moving_functions.sql) (in query: SELECT k, groupArrayMovingAvg(v) FROM (SELECT * FROM moving_sum_num ORDER BY k, dt) GROUP BY k ORDER BY k FORMAT TabSeparatedWithNamesAndTypes;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:17.792365 [ 8202 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38782, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:17.793947 [ 5326 ] {603e6193-1eed-4511-978c-8509ba8e65a5} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:09:17.794838 [ 8200 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43088, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:19.316896 [ 8200 ] {9ca6dceb-59d6-42de-ae6a-0b2aabe0c814} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59642) (comment: 02707_skip_index_with_in.sql) (in query: EXPLAIN SELECT count() FROM t_skip_index_in WHERE c IN (SELECT throwIf(1)) SETTINGS use_skip_indexes = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 18. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x00000000116faad2 20. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:407: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001289273a 21. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:370: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001289256e 22. /build/src/Storages/MergeTree/RPNBuilder.h:242: DB::RPNBuilder::traverseTree(DB::RPNBuilderTreeNode const&) @ 0x00000000128a2f84 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::RPNBuilder::RPNBuilder(DB::ActionsDAG::Node const*, std::shared_ptr, std::function const&) @ 0x000000001289787b 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012891399 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000012897096 26. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001318fa36 27. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001318eafd 28. /build/contrib/llvm-project/libcxx/include/vector:438: DB::SourceStepWithFilter::applyFilters() @ 0x000000001320027a 29. /build/src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000013200145 30. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fea53 31. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 2025.09.25 21:09:19.329153 [ 8200 ] {9ca6dceb-59d6-42de-ae6a-0b2aabe0c814} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 18. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x00000000116faad2 20. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:407: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001289273a 21. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:370: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001289256e 22. /build/src/Storages/MergeTree/RPNBuilder.h:242: DB::RPNBuilder::traverseTree(DB::RPNBuilderTreeNode const&) @ 0x00000000128a2f84 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::RPNBuilder::RPNBuilder(DB::ActionsDAG::Node const*, std::shared_ptr, std::function const&) @ 0x000000001289787b 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012891399 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000012897096 26. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001318fa36 27. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001318eafd 28. /build/contrib/llvm-project/libcxx/include/vector:438: DB::SourceStepWithFilter::applyFilters() @ 0x000000001320027a 29. /build/src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000013200145 30. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fea53 31. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 2025.09.25 21:09:24.076135 [ 8201 ] {d451fd06-5aeb-4fea-b9b4-5b4779bdea93} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59722) (comment: 01798_uniq_theta_union_intersect_not.sql) (in query: SELECT 'uniqTheta union 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:24.080377 [ 8201 ] {d451fd06-5aeb-4fea-b9b4-5b4779bdea93} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:24.541251 [ 3591 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f6626a83-f228-4233-bb21-8b2f18a0f694::202509_1_30_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:24.769159 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:26.217155 [ 5326 ] {5d00354d-4556-44db-a1b2-35d57256e9d2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42852) (comment: 02765_queries_with_subqueries_profile_events.sh) (in query: DROP DATABASE IF EXISTS test_otoy2wn5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:26.222621 [ 5326 ] {5d00354d-4556-44db-a1b2-35d57256e9d2} DynamicQueryHandler: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:30.013217 [ 8201 ] {7ab6b145-d5a5-41fa-af64-8cc323d7530e} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59776) (comment: 02497_if_transform_strings_to_enum.sql) (in query: SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:09:30.019436 [ 8201 ] {7ab6b145-d5a5-41fa-af64-8cc323d7530e} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:09:30.194494 [ 8201 ] {bb0782b2-4092-461d-873c-6bd2deb01788} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: While processing transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')): While processing SELECT transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59776) (comment: 02497_if_transform_strings_to_enum.sql) (in query: EXPLAIN SYNTAX SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc3c24 10. /build/src/Interpreters/ActionsVisitor.cpp:658: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111d1eb1 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111dc3af 12. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d430d 13. /build/src/Interpreters/ActionsVisitor.cpp:812: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d84d8 14. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000111c9815 15. /build/src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000111a8f21 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x00000000111b4a30 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000111b9bc9 18. /build/src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000011617129 19. /build/src/Interpreters/InterpreterSelectQuery.cpp:812: 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)::$_0::operator()(bool) const @ 0x000000001160ef30 20. /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) @ 0x000000001160a0b4 21. /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) @ 0x0000000011606dac 22. /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&) @ 0x0000000011606b11 23. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157ef9b 24. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f250 25. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f25b 26. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f25b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000115794ee 28. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577927 29. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:09:30.207424 [ 8201 ] {bb0782b2-4092-461d-873c-6bd2deb01788} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: While processing transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')): While processing SELECT transform(number, NULL, _CAST(['google', 'censor.net', 'yahoo'], 'Array(Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4))'), _CAST('other', 'Enum8(\'censor.net\' = 1, \'google\' = 2, \'other\' = 3, \'yahoo\' = 4)')) FROM system.numbers LIMIT 10. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc3c24 10. /build/src/Interpreters/ActionsVisitor.cpp:658: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111d1eb1 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111dc3af 12. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d430d 13. /build/src/Interpreters/ActionsVisitor.cpp:812: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d84d8 14. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000111c9815 15. /build/src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000111a8f21 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x00000000111b4a30 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000111b9bc9 18. /build/src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000011617129 19. /build/src/Interpreters/InterpreterSelectQuery.cpp:812: 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)::$_0::operator()(bool) const @ 0x000000001160ef30 20. /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) @ 0x000000001160a0b4 21. /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) @ 0x0000000011606dac 22. /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&) @ 0x0000000011606b11 23. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157ef9b 24. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f250 25. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f25b 26. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f25b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000115794ee 28. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577927 29. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:09:30.337663 [ 8201 ] {dd5c331d-218a-4db0-a5cb-2998d929b303} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59776) (comment: 02497_if_transform_strings_to_enum.sql) (in query: EXPLAIN QUERY TREE run_passes = 1 SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584b94 17. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157a042 18. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577927 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:09:30.340591 [ 8201 ] {dd5c331d-218a-4db0-a5cb-2998d929b303} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(number, NULL, ['google', 'censor.net', 'yahoo'], 'other') FROM system.numbers LIMIT 10. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/transform.cpp:0: DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b805281 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584b94 17. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157a042 18. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577927 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:09:31.657302 [ 7897 ] {d085a9b1-3390-4883-960c-6e46c73f9da6} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37520) (comment: 01710_projections.sql) (in query: select * from projection_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:31.658788 [ 7897 ] {d085a9b1-3390-4883-960c-6e46c73f9da6} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:31.844412 [ 7897 ] {6340b9ba-0991-4430-8af1-e18e60cbee75} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37520) (comment: 01710_projections.sql) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:31.847180 [ 7897 ] {6340b9ba-0991-4430-8af1-e18e60cbee75} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.124988 [ 7897 ] {022c9197-325e-46ef-9b5b-bfbeb1493bd3} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37520) (comment: 01710_projections.sql) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) / count(), avg((kbytes * 8) / duration) from projection_test where domain = '1' group by dt_m order by dt_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.129244 [ 7897 ] {022c9197-325e-46ef-9b5b-bfbeb1493bd3} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131ff1a8 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 6. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.249583 [ 2926 ] {47ad7572-09a1-4cd4-b190-d04375313a40} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37520) (comment: 01710_projections.sql) (in query: DROP DATABASE IF EXISTS test_ctdmp714 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.251250 [ 2926 ] {47ad7572-09a1-4cd4-b190-d04375313a40} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:32.335741 [ 7897 ] {ad746c33-d236-49a8-b7d4-74a891b112b5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37536) (comment: 01710_projections.sql) (in query: DROP DATABASE IF EXISTS test_ctdmp714 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.338984 [ 7897 ] {ad746c33-d236-49a8-b7d4-74a891b112b5} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:32.467800 [ 7932 ] {28da1f48-ab69-400c-867b-92ec276a6a9b} 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.10508.altinitytest (altinity build)) (from [::1]:37550) (comment: 01710_projections.sql) (in query: DROP DATABASE IF EXISTS test_ctdmp714 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:32.469559 [ 7932 ] {28da1f48-ab69-400c-867b-92ec276a6a9b} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:35.340947 [ 7628 ] {6ce42d3f-ea18-401e-8605-d3aa048109af} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02311_range_hashed_dictionary_range_cast.sql) (in query: /* ddl_entry=query-0000000038 */ TRUNCATE DICTIONARY test_5.range_hashed_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:09:35.371281 [ 7628 ] {6ce42d3f-ea18-401e-8605-d3aa048109af} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37614) (comment: 02311_range_hashed_dictionary_range_cast.sql) (in query: DROP DICTIONARY range_hashed_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:09:35.413124 [ 7628 ] {6ce42d3f-ea18-401e-8605-d3aa048109af} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.437550 [ 7932 ] {7519b8dd-11cc-4859-bf98-c46c44b02a97} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51072) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.444290 [ 7932 ] {7519b8dd-11cc-4859-bf98-c46c44b02a97} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.494748 [ 7932 ] {86e14d03-e1ec-40e1-aa75-eb1af794d838} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51072) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.497970 [ 7932 ] {86e14d03-e1ec-40e1-aa75-eb1af794d838} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.735964 [ 7932 ] {dc9aa0fe-74c6-4766-83b0-dd11c8b86ed8} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51072) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.756042 [ 7932 ] {dc9aa0fe-74c6-4766-83b0-dd11c8b86ed8} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.858920 [ 4992 ] {56123f67-a4af-44a2-8427-2500e831dd36} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51144) (comment: 02677_grace_hash_limit_race.sql) (in query: SELECT count() FROM ( SELECT f.id FROM test_grace_hash AS f LEFT JOIN test_grace_hash AS d ON f.id = d.id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.859865 [ 7932 ] {97003684-845d-47ae-a6e6-a2633151e4a0} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51072) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.865937 [ 7932 ] {97003684-845d-47ae-a6e6-a2633151e4a0} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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&) @ 0x0000000011034937 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:41.911858 [ 4992 ] {56123f67-a4af-44a2-8427-2500e831dd36} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:09:42.071564 [ 4665 ] {de940f0c-780c-4255-b8bc-b8df2ead9ebf} 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.10508.altinitytest (altinity build)) (from [::1]:60064) (comment: 02677_grace_hash_limit_race.sql) (in query: DROP DATABASE IF EXISTS test_j56v4ms5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:42.079555 [ 4665 ] {de940f0c-780c-4255-b8bc-b8df2ead9ebf} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:42.824065 [ 7628 ] {39553bfc-abab-4538-bfef-5e3c0299f889} 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.10508.altinitytest (altinity build)) (from [::1]:51164) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: DROP DATABASE IF EXISTS test_13;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:42.830646 [ 7628 ] {39553bfc-abab-4538-bfef-5e3c0299f889} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:09:43.636778 [ 7640 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:44.152717 [ 7640 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:44.463087 [ 4665 ] {53430c10-782b-4691-af25-1e2afbd65c34} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (in query: /* ddl_entry=query-0000000039 */ CREATE TABLE test_5.range_filter_custom_range_test UUID '0f06b9af-49d9-4321-af3e-29d13de6d020' (`k` UInt64) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 28721, min_bytes_for_wide_part = 1031600078, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 46, min_bytes_for_full_part_storage = 317067678, compact_parts_max_bytes_to_buffer = 116135186, compact_parts_max_granules_to_buffer = 35, compact_parts_merge_max_bytes_to_prefetch_part = 32469014, merge_max_block_size = 3866, old_parts_lifetime = 200., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 994704, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 17015603, concurrent_part_removal_threshold = 42, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75862, primary_key_compress_block_size = 12746), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 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>) @ 0x0000000012a75a0c 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>&&) @ 0x0000000012a754d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 19. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 21. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:09:44.512512 [ 4665 ] {53430c10-782b-4691-af25-1e2afbd65c34} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51230) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (in query: CREATE TABLE range_filter_custom_range_test (`k` UInt64) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 28721, min_bytes_for_wide_part = 1031600078, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 46, min_bytes_for_full_part_storage = 317067678, compact_parts_max_bytes_to_buffer = 116135186, compact_parts_max_granules_to_buffer = 35, compact_parts_merge_max_bytes_to_prefetch_part = 32469014, merge_max_block_size = 3866, old_parts_lifetime = 200., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 994704, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 17015603, concurrent_part_removal_threshold = 42, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75862, primary_key_compress_block_size = 12746), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 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>) @ 0x0000000012a75a0c 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>&&) @ 0x0000000012a754d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 19. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 21. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:09:44.539841 [ 4665 ] {53430c10-782b-4691-af25-1e2afbd65c34} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 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>) @ 0x0000000012a75a0c 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>&&) @ 0x0000000012a754d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 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 @ 0x00000000122534a7 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) @ 0x000000001155d837 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 19. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 21. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:09:44.986053 [ 4665 ] {4951e0e7-0942-4b52-9d85-c6d18ea41f56} executeQuery: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51266) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: SHOW GRANTS FOR user1_03006_test_13_25456), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::getEntities() const @ 0x0000000011e078da 10. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:181: DB::InterpreterShowGrantsQuery::getGrantQueries() const @ 0x0000000011e075e1 11. /build/src/Common/COW.h:284: DB::InterpreterShowGrantsQuery::executeImpl() @ 0x0000000011e06d4b 12. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::execute() @ 0x0000000011e06cc7 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:45.000542 [ 4665 ] {4951e0e7-0942-4b52-9d85-c6d18ea41f56} TCPHandler: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::getEntities() const @ 0x0000000011e078da 10. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:181: DB::InterpreterShowGrantsQuery::getGrantQueries() const @ 0x0000000011e075e1 11. /build/src/Common/COW.h:284: DB::InterpreterShowGrantsQuery::executeImpl() @ 0x0000000011e06d4b 12. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::execute() @ 0x0000000011e06cc7 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:45.033158 [ 7932 ] {8183320a-5c86-490c-aa12-5f21614e5a53} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51252) (comment: 02789_object_type_invalid_num_of_rows.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:45.041676 [ 7932 ] {8183320a-5c86-490c-aa12-5f21614e5a53} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:45.619889 [ 3020 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:45.704609 [ 4992 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:46.553039 [ 7898 ] {4d9b35b0-5213-4014-b979-6a87cfd00b9d} executeQuery: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51318) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: REVOKE ALL ON test_13.* FROM user1_03006_test_13_25456), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x0000000011df55d2 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:46.569183 [ 7898 ] {4d9b35b0-5213-4014-b979-6a87cfd00b9d} TCPHandler: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x0000000011df55d2 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:46.630636 [ 3311 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:47.132007 [ 7898 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:47.186171 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:47.251480 [ 4992 ] {52dab326-f6fa-4149-b087-ec99cd9e9b37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50852) (comment: 01825_new_type_json_12.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(obj.key_0[]))) as path FROM t_json_12 order by path;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:47.263047 [ 4992 ] {52dab326-f6fa-4149-b087-ec99cd9e9b37} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:47.372898 [ 7615 ] {c5c01abe-e7a7-4f99-9c8b-c6e842cbd4d1} executeQuery: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_a575b83b-1e97-41ce-aa30-3e41f03bc817` (a575b83b-1e97-41ce-aa30-3e41f03bc817) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51326) (comment: 01358_constexpr_constraint.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010d2a559 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f934c8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:47.377285 [ 7615 ] {c5c01abe-e7a7-4f99-9c8b-c6e842cbd4d1} TCPHandler: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_a575b83b-1e97-41ce-aa30-3e41f03bc817` (a575b83b-1e97-41ce-aa30-3e41f03bc817) is violated at row 1. Expression: (0). Column values: . (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&) @ 0x0000000010d2a559 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f934c8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:47.635922 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:47.799176 [ 4665 ] {9a0ebd41-b042-4885-a8c5-a9991b8a7054} executeQuery: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50866) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: SHOW GRANTS FOR user1_03006_test_13_25456), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::getEntities() const @ 0x0000000011e078da 10. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:181: DB::InterpreterShowGrantsQuery::getGrantQueries() const @ 0x0000000011e075e1 11. /build/src/Common/COW.h:284: DB::InterpreterShowGrantsQuery::executeImpl() @ 0x0000000011e06d4b 12. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::execute() @ 0x0000000011e06cc7 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:47.897372 [ 4665 ] {9a0ebd41-b042-4885-a8c5-a9991b8a7054} TCPHandler: Code: 511. DB::Exception: There is no role `user1_03006_test_13_25456` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::getEntities() const @ 0x0000000011e078da 10. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:181: DB::InterpreterShowGrantsQuery::getGrantQueries() const @ 0x0000000011e075e1 11. /build/src/Common/COW.h:284: DB::InterpreterShowGrantsQuery::executeImpl() @ 0x0000000011e06d4b 12. /build/src/Interpreters/Access/InterpreterShowGrantsQuery.cpp:0: DB::InterpreterShowGrantsQuery::execute() @ 0x0000000011e06cc7 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:48.191779 [ 3351 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:48.508569 [ 7898 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:48.641565 [ 3407 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:48.854820 [ 3602 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1aef7ea7-cbf0-4db2-93e7-d853aa133566::202509_1_55_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:49.198469 [ 3324 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:49.273037 [ 7615 ] {6390b933-14c7-43b8-aab7-1bc27831117a} executeQuery: Code: 511. DB::Exception: There is no role `user2_03006_test_13_20735` in user directories. (UNKNOWN_ROLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50888) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: REVOKE ALL ON test_13.* FROM user2_03006_test_13_20735), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x0000000011df55d2 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.293733 [ 7615 ] {6390b933-14c7-43b8-aab7-1bc27831117a} TCPHandler: Code: 511. DB::Exception: There is no role `user2_03006_test_13_20735` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Access/RolesOrUsersSet.cpp:92: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&)::$_0::operator()(String const&) const @ 0x000000001087b413 7. /build/src/Access/RolesOrUsersSet.cpp:98: DB::RolesOrUsersSet::init(DB::ASTRolesOrUsersSet const&, DB::AccessControl const*, std::optional, DB::UUIDTag>> const&) @ 0x000000001087af5d 8. /build/src/Access/RolesOrUsersSet.cpp:65: DB::RolesOrUsersSet::RolesOrUsersSet(DB::ASTRolesOrUsersSet const&, DB::AccessControl const&, std::optional, DB::UUIDTag>> const&) @ 0x000000001087b2e3 9. /build/src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x0000000011df55d2 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.330206 [ 4992 ] {a3c01449-bc40-4088-8e60-e9fb495598bf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42396) (comment: 01846_alter_column_without_type_bugfix.sql) (in query: DROP DATABASE IF EXISTS test_f07rm8a4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.342187 [ 4992 ] {a3c01449-bc40-4088-8e60-e9fb495598bf} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:49.439748 [ 7932 ] {08d6ba9a-5c0c-47dc-968e-14ec3931606f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51294) (comment: 00961_check_table.sql) (in query: CHECK TABLE mt_table SETTINGS 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.462999 [ 7932 ] {08d6ba9a-5c0c-47dc-968e-14ec3931606f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.576176 [ 4665 ] {144a2fad-0eae-45b6-a2f1-e2531a35eec4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42412) (comment: 01846_alter_column_without_type_bugfix.sql) (in query: DROP DATABASE IF EXISTS test_f07rm8a4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:49.585871 [ 4665 ] {144a2fad-0eae-45b6-a2f1-e2531a35eec4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:49.671901 [ 3283 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:50.012852 [ 4992 ] {} ServerErrorHandler: Code: 516. DB::Exception: user2_03006_test_13_20735: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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 @ 0x000000001079d5d5 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d89e 5. /build/src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171d372 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x0000000012cbb7ca 7. /build/src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x0000000012cb4490 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 13. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:50.204942 [ 3263 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:50.677080 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:50.952892 [ 4665 ] {b87fe581-3b2e-4f3e-8f99-c85e4905eef6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50910) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: DROP DATABASE IF EXISTS test_13), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:50.962280 [ 4665 ] {b87fe581-3b2e-4f3e-8f99-c85e4905eef6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:51.031257 [ 4992 ] {d5ffb934-b2e9-41ec-95fe-58b6f589bbd0} DatabaseReplicated (test_5): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.09.25 21:09:51.086833 [ 4992 ] {d5ffb934-b2e9-41ec-95fe-58b6f589bbd0} 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.10508.altinitytest (altinity build)) (from [::1]:50904) (comment: 01560_optimize_on_insert_zookeeper.sql) (in query: CREATE TABLE empty1 (`key` UInt32, `val` UInt32, `date` Datetime) ENGINE = ReplicatedSummingMergeTree('/clickhouse/tables/{database}/test_01560_optimize_on_insert', '1', val) PARTITION BY date ORDER BY key SETTINGS index_granularity = 8569, 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 = 0, compact_parts_max_bytes_to_buffer = 210795889, compact_parts_max_granules_to_buffer = 38, compact_parts_merge_max_bytes_to_prefetch_part = 25526638, merge_max_block_size = 22000, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 376641, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 8623502738, index_granularity_bytes = 13820041, concurrent_part_removal_threshold = 74, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 36853, primary_key_compress_block_size = 49879), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:51.100490 [ 4992 ] {d5ffb934-b2e9-41ec-95fe-58b6f589bbd0} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:51.289900 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:51.595302 [ 7615 ] {6644b73e-5b23-4e0d-9593-9a754705b8df} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50918) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (in query: select * from dist_01528 where dummy = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:1504: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x00000000122334f2 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:51.603162 [ 7615 ] {6644b73e-5b23-4e0d-9593-9a754705b8df} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:1504: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x00000000122334f2 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:51.699383 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:52.141728 [ 7898 ] {842f8a5d-8b34-4889-bc24-7672b6a856ba} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42432) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (in query: DROP DATABASE IF EXISTS test_g1u9s736 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:52.144490 [ 7898 ] {842f8a5d-8b34-4889-bc24-7672b6a856ba} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:52.301891 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:52.778667 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:52.986312 [ 7898 ] {506169c4-5827-4c5d-b127-d9612aed2e66} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50950) (comment: 01300_svg.sql) (in query: SELECT SVG((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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:53.000569 [ 7898 ] {506169c4-5827-4c5d-b127-d9612aed2e66} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:53.315580 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:53.785049 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:54.322193 [ 3396 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:54.791989 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:55.327743 [ 3131 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:55.796846 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:55.841880 [ 7898 ] {d21c3087-a564-4ded-91b5-6995461b5cce} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50966) (comment: 01080_check_for_error_incorrect_size_of_nested_column.sql) (in query: DROP DICTIONARY test_cfv94ib4.test_dict_01080), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:55.844668 [ 7898 ] {d21c3087-a564-4ded-91b5-6995461b5cce} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.072388 [ 7615 ] {ea733a77-7f49-417f-ad03-40eb2abcb240} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50976) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized (toDate(DateTime) is always monotonic, but we cannot relaxing the predicates to do trivial count()) select count() from test1 where p > toDateTime('2020-09-01 10: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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.076675 [ 7615 ] {ea733a77-7f49-417f-ad03-40eb2abcb240} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.088527 [ 7604 ] {c98677f5-d032-4931-a0ff-4597e191d7b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42492) (comment: 01080_check_for_error_incorrect_size_of_nested_column.sql) (in query: DROP DATABASE IF EXISTS test_cfv94ib4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.092191 [ 7604 ] {c98677f5-d032-4931-a0ff-4597e191d7b1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:56.176651 [ 7902 ] {0ac3239d-707b-471f-a6b6-46e072c4e225} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42502) (comment: 01080_check_for_error_incorrect_size_of_nested_column.sql) (in query: DROP DATABASE IF EXISTS test_cfv94ib4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.178649 [ 7902 ] {0ac3239d-707b-471f-a6b6-46e072c4e225} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:56.284414 [ 8473 ] {575c1190-5991-43d5-bae7-8b269100f90b} 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.10508.altinitytest (altinity build)) (from [::1]:42524) (comment: 01080_check_for_error_incorrect_size_of_nested_column.sql) (in query: DROP DATABASE IF EXISTS test_cfv94ib4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.294422 [ 8473 ] {575c1190-5991-43d5-bae7-8b269100f90b} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:56.335624 [ 3305 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:56.802096 [ 3201 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:56.843879 [ 7615 ] {ceeb108f-53ec-47ca-8b59-056cb43e247f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50976) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized (some predicate depends on non-partition_expr columns) select count() FROM test1 where toDate(p) = '2020-09-01' and k = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:56.850737 [ 7615 ] {ceeb108f-53ec-47ca-8b59-056cb43e247f} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.255601 [ 7604 ] {7bfaecbe-4a55-4b70-8c2b-0b4df80db909} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, ALL, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.260646 [ 7604 ] {7bfaecbe-4a55-4b70-8c2b-0b4df80db909} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.332296 [ 7604 ] {e2aa2473-eb92-4751-b662-5b42d4df5b44} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, INNER, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.346622 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:57.391813 [ 7604 ] {e2aa2473-eb92-4751-b662-5b42d4df5b44} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.495487 [ 7604 ] {ceb2dff2-34f9-4c0b-8b92-93fdb47f7d06} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, FULL, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.505223 [ 7604 ] {ceb2dff2-34f9-4c0b-8b92-93fdb47f7d06} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.605827 [ 7604 ] {f41b0110-f146-4c81-90c7-0ab6b4ee9990} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, ALL, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.607804 [ 7604 ] {f41b0110-f146-4c81-90c7-0ab6b4ee9990} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.701561 [ 7604 ] {6532d33a-7cae-4d20-861c-0550965aad1d} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, INNER, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.705956 [ 7604 ] {6532d33a-7cae-4d20-861c-0550965aad1d} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.793811 [ 7604 ] {dbc167ad-c645-4e0b-bc5a-a1adf5738b0b} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, FULL, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.795928 [ 7604 ] {dbc167ad-c645-4e0b-bc5a-a1adf5738b0b} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:452: 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&) @ 0x00000000122952df 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.807931 [ 3028 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:57.977829 [ 7604 ] {2bd11a16-4e2c-4625-8d8a-ec3730f4169e} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50784) (comment: 03197_storage_join_strictness_type_restriction.sql) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANY, FULL, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:446: 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&) @ 0x00000000122958eb 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:57.993445 [ 7604 ] {2bd11a16-4e2c-4625-8d8a-ec3730f4169e} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:446: 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&) @ 0x00000000122958eb 5. /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 @ 0x00000000122534a7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:09:58.351321 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:58.815400 [ 3490 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:59.356684 [ 3329 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:09:59.663391 [ 7615 ] {b9670804-e006-4c5a-97ae-65e5be03bb13} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50976) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: -- non-optimized select count() from test_tuple array join [p,p] as c where toDate(p) = '2020-09-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:59.669794 [ 7615 ] {b9670804-e006-4c5a-97ae-65e5be03bb13} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001317fe6d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2030: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193a27 7. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:09:59.827497 [ 3374 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:00.176604 [ 7615 ] {4dbc0d97-88de-469a-846c-bcc8c2eaa214} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50976) (comment: 01505_trivial_count_with_partition_predicate.sql) (in query: select count() from test_tuple array join [1,2] as c where toDate(p) = '2020-09-01' settings max_rows_to_read = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:00.179586 [ 7615 ] {4dbc0d97-88de-469a-846c-bcc8c2eaa214} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:00.179727 [ 2929 ] {66d59ffb-3898-49f2-9978-6e1c2d92bb5f} executeQuery: Code: 130. DB::Exception: Array does not start with '[' character: value Hello cannot be parsed as Array(String) for query parameter 'x'. (CANNOT_READ_ARRAY_FROM_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50870) (comment: 02723_param_exception_message_context.sh) (in query: SELECT {x:Array(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010ce0634 5. /build/src/IO/BufferBase.h:41: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000118f7f1e 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 10. /build/src/Interpreters/executeQuery.cpp:847: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d3a7 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:00.203318 [ 2929 ] {66d59ffb-3898-49f2-9978-6e1c2d92bb5f} TCPHandler: Code: 130. DB::Exception: Array does not start with '[' character: value Hello cannot be parsed as Array(String) for query parameter 'x'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000010ce0634 5. /build/src/IO/BufferBase.h:41: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000118f7f1e 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f87d8 10. /build/src/Interpreters/executeQuery.cpp:847: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d3a7 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:00.364081 [ 3441 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:00.837053 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:01.372720 [ 3016 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:01.529354 [ 7604 ] {9a77353a-b14c-44f8-b0de-fe4c8d2fb073} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter1187636744223705248, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50898) (comment: 01258_wrong_cast_filimonov.sql) (in query: CREATE TABLE x (`id` UInt64, `t` AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) DEFAULT arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)])) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 62575, min_bytes_for_wide_part = 749148471, ratio_of_defaults_for_sparse_serialization = 0.9319577217102051, replace_long_file_name_to_hash = true, max_file_name_length = 65, min_bytes_for_full_part_storage = 269269996, compact_parts_max_bytes_to_buffer = 187786403, compact_parts_max_granules_to_buffer = 31, compact_parts_merge_max_bytes_to_prefetch_part = 16315483, merge_max_block_size = 10788, old_parts_lifetime = 475., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 118641, vertical_merge_algorithm_min_columns_to_activate = 78, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 28452059, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 28061, primary_key_compress_block_size = 54331), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000000710dab5 5. /build/src/Functions/FunctionsConversion.cpp:5214: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f82ba 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000010fc4660 8. /build/src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc3d1c 9. /build/src/Interpreters/ActionsVisitor.cpp:658: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111d1eb1 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111dc3af 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d430d 12. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000111c9815 13. /build/src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000111a8f21 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000111b6f34 15. /build/src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000111b7389 16. /build/src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df531 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 19. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:10:01.534332 [ 7604 ] {9a77353a-b14c-44f8-b0de-fe4c8d2fb073} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter1187636744223705248, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000000710dab5 5. /build/src/Functions/FunctionsConversion.cpp:5214: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f82ba 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000010fc4660 8. /build/src/Interpreters/ActionsDAG.cpp:254: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc3d1c 9. /build/src/Interpreters/ActionsVisitor.cpp:658: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111d1eb1 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000111dc3af 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x00000000111d430d 12. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000111c9815 13. /build/src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000111a8f21 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000111b6f34 15. /build/src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000111b7389 16. /build/src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df531 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 19. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:10:01.852565 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:02.378467 [ 3199 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:02.859751 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:03.387413 [ 3115 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:03.887826 [ 2975 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:04.393115 [ 3032 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:04.895242 [ 3070 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:05.402985 [ 3380 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:05.898677 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:06.235177 [ 7598 ] {ed8aaf53-fc84-4eb0-b838-50ccfe19e395} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51008) (comment: 02103_with_names_and_types_parallel_parsing.sh) (in query: SELECT number, range(number + 10) AS array, toString(number) AS string FROM numbers(10) FORMAT TSVRawWithNames), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:06.256937 [ 7598 ] {ed8aaf53-fc84-4eb0-b838-50ccfe19e395} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:06.409444 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:06.720070 [ 3587 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {06e0dcf3-6e7a-4ddb-850b-40d5fef4d059::202509_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:06.907444 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:07.412845 [ 3191 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:07.914190 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:08.328040 [ 8473 ] {94d94b5f-a864-42b9-bbb8-9f2c4aa2c928} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50938) (comment: 02883_array_scalar_mult_div_modulo.sql) (in query: SELECT [1] / '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:10:08.357568 [ 8473 ] {94d94b5f-a864-42b9-bbb8-9f2c4aa2c928} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:10:08.424110 [ 3318 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:08.794071 [ 8473 ] {82749e98-7843-4736-a507-712a11060b74} executeQuery: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_pj0n1smf: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_pj0n1smf.dict_03273_dictionary_rbac_test_pj0n1smf: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_pj0n1smf, 'value', 1). (ACCESS_DENIED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45316) (comment: 03273_dictionary_rbac.sh) (in query: SELECT dictGet(dict_03273_dictionary_rbac_test_pj0n1smf, 'value', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dd564 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107dd1d7 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000107dc8ba 7. /build/src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000107c59e3 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000110e1534 9. /build/src/Functions/FunctionsExternalDictionaries.h:0: DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000073fbff6 10. /build/src/Functions/FunctionsExternalDictionaries.h:431: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f8d84 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/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 @ 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 2025.09.25 21:10:08.840042 [ 8473 ] {82749e98-7843-4736-a507-712a11060b74} TCPHandler: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_pj0n1smf: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_pj0n1smf.dict_03273_dictionary_rbac_test_pj0n1smf: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_pj0n1smf, 'value', 1). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dd564 5. /build/src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107dd1d7 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000107dc8ba 7. /build/src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000107c59e3 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000110e1534 9. /build/src/Functions/FunctionsExternalDictionaries.h:0: DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000073fbff6 10. /build/src/Functions/FunctionsExternalDictionaries.h:431: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f8d84 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/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 @ 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::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011050d10 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 2025.09.25 21:10:08.931799 [ 3450 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:09.440091 [ 3024 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:09.665986 [ 7598 ] {86404026-66f2-4911-bf4a-6fa62a82e893} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45336) (comment: 03273_dictionary_rbac.sh) (in query: DROP DICTIONARY IF EXISTS dict_03273_dictionary_rbac_test_pj0n1smf;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:09.675782 [ 7598 ] {86404026-66f2-4911-bf4a-6fa62a82e893} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:09.936859 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:10.294941 [ 7902 ] {a981b334-3c41-41fd-8ad9-27f8147e92a1} executeQuery: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3: while executing 'FUNCTION arrayMap(x UInt8, y UInt8 -> plus(x, y) :: 1, _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String) :: 3) -> arrayMap(x UInt8, y UInt8 -> plus(x, y), _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String), _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String)) Array(UInt16) : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45350) (comment: 03001_bad_error_message_higher_order_functions.sh) (in query: SELECT arrayMap((x,y) -> x + y, [1,2,3], [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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000b9733eb 4. /build/src/Functions/array/FunctionArrayMapped.h:0: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97749d 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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:10:10.320456 [ 7902 ] {a981b334-3c41-41fd-8ad9-27f8147e92a1} TCPHandler: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3: while executing 'FUNCTION arrayMap(x UInt8, y UInt8 -> plus(x, y) :: 1, _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String) :: 3) -> arrayMap(x UInt8, y UInt8 -> plus(x, y), _CAST([1, 2, 3]_Array(UInt8), 'Array(UInt8)'_String), _CAST([1, 2]_Array(UInt8), 'Array(UInt8)'_String)) Array(UInt16) : 4'. (SIZES_OF_ARRAYS_DONT_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000b9733eb 4. /build/src/Functions/array/FunctionArrayMapped.h:0: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97749d 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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:10:10.446939 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:10.949845 [ 3342 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:11.452456 [ 3040 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:11.663560 [ 8473 ] {c68d039a-d609-46ae-950b-eecfeb891ffa} executeQuery: Code: 199. DB::Exception: There is no quota `q2_01297` in user directories. (UNKNOWN_QUOTA) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45326) (comment: 01297_create_quota.sql) (in query: SHOW CREATE QUOTA q2_01297;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:340: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000011e00700 7. /build/contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000011dffd5e 8. /build/src/Common/COW.h:284: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000011dff588 9. /build/src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000011dff507 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:11.667750 [ 8473 ] {c68d039a-d609-46ae-950b-eecfeb891ffa} TCPHandler: Code: 199. DB::Exception: There is no quota `q2_01297` in user directories. (UNKNOWN_QUOTA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000108245f6 5. /build/src/Access/IAccessStorage.cpp:80: ? @ 0x000000001082454f 6. /build/src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:340: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000011e00700 7. /build/contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000011dffd5e 8. /build/src/Common/COW.h:284: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000011dff588 9. /build/src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000011dff507 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:11.968037 [ 3262 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:12.458549 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:12.976154 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:13.466485 [ 3448 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:13.983471 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:14.420677 [ 3591 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e7d6e632-4c15-41c3-97fd-9f4db39d51ac::202509_1_71_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:14.472364 [ 3399 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:14.995838 [ 3216 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:15.394005 [ 7604 ] {47d1e957-7254-40c9-b8ec-cbd2209e8ca9} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45352) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:15.409217 [ 7604 ] {47d1e957-7254-40c9-b8ec-cbd2209e8ca9} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:15.476276 [ 3410 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:16.004792 [ 3184 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:16.491537 [ 3139 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:16.980164 [ 7604 ] {f6314dda-4eb5-40ad-8cc6-5747c9d6599a} executeQuery: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45352) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:16.984823 [ 7604 ] {f6314dda-4eb5-40ad-8cc6-5747c9d6599a} TCPHandler: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:17.011037 [ 3125 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:17.344626 [ 7934 ] {7c6b1fa8-1241-410d-9109-c5e83ccecea8} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (ILLEGAL_DIVISION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45456) (comment: 02481_prewhere_filtered_rows_div_by_zero.sql) (in query: -- Check that division by zero occurs on some rows SELECT intDiv(b, c) FROM test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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(int, int) @ 0x00000000084fd5f4 5. /build/src/Functions/DivisionUtils.h:59: void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000958dd8b 6. /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 @ 0x000000000976674a 7. /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&&) @ 0x0000000009762868 8. /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&&) @ 0x0000000009710383 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 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 @ 0x0000000011197afd 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 18. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:17.347424 [ 7934 ] {7c6b1fa8-1241-410d-9109-c5e83ccecea8} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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(int, int) @ 0x00000000084fd5f4 5. /build/src/Functions/DivisionUtils.h:59: void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000958dd8b 6. /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 @ 0x000000000976674a 7. /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&&) @ 0x0000000009762868 8. /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&&) @ 0x0000000009710383 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 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 @ 0x0000000011197afd 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 18. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:17.498173 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:18.026942 [ 3137 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:18.492701 [ 7604 ] {b06e0608-debc-4fd9-8a0f-e501493c9bb8} executeQuery: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45352) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:18.497049 [ 7604 ] {b06e0608-debc-4fd9-8a0f-e501493c9bb8} TCPHandler: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&&) @ 0x000000001106692b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110632c3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:10:18.505134 [ 3253 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:18.894224 [ 7934 ] {e2729fb2-62d6-41f8-b877-77671f006ca1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45456) (comment: 02481_prewhere_filtered_rows_div_by_zero.sql) (in query: -- Test that now division by zero doesn't occur without explicit condition SELECT intDiv(b, c) FROM test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906b1a 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:10:18.898311 [ 7934 ] {e2729fb2-62d6-41f8-b877-77671f006ca1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906b1a 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:10:19.034678 [ 3478 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:19.511146 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:19.680437 [ 7604 ] {e355d9cb-e074-4fc2-90dc-68f5e3a7298a} 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.10508.altinitytest (altinity build)) (from [::1]:45352) (comment: 02374_analyzer_join_using.gen.sql) (in query: SELECT 1 FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:10:19.714951 [ 7604 ] {e355d9cb-e074-4fc2-90dc-68f5e3a7298a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:10:19.886726 [ 7598 ] {cdd2fea5-20bf-45e7-92ae-0d3cf73dd510} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44638) (comment: 02374_analyzer_join_using.gen.sql) (in query: DROP DATABASE IF EXISTS test_ffrcifs7 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:10:19.904003 [ 7598 ] {cdd2fea5-20bf-45e7-92ae-0d3cf73dd510} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:20.045472 [ 3027 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:20.516696 [ 3360 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:21.049073 [ 3288 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:21.105634 [ 4904 ] {b3f77ae1-1183-4968-a88f-00b6d3300eea} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT IPv4StringToNum('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:279: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070c78b1 5. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070c67d3 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:21.116484 [ 4904 ] {b3f77ae1-1183-4968-a88f-00b6d3300eea} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:279: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070c78b1 5. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070c67d3 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:21.521868 [ 3023 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:22.060751 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:22.328167 [ 4904 ] {1fba3903-753f-4773-b306-c24a3fbe455d} executeQuery: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv4('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000070d08eb 4. /build/src/IO/ReadHelpers.h:0: 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&&) @ 0x00000000072849ce 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007280051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:22.336028 [ 4904 ] {1fba3903-753f-4773-b306-c24a3fbe455d} TCPHandler: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000070d08eb 4. /build/src/IO/ReadHelpers.h:0: 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&&) @ 0x00000000072849ce 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007280051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:22.429525 [ 5310 ] {3f35f049-91ac-4a02-97f8-4d4f68104e51} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02366_direct_dictionary_dict_has.sql) (in query: /* ddl_entry=query-0000000047 */ DROP DICTIONARY test_5.test_dictionary 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:10:22.447314 [ 5310 ] {3f35f049-91ac-4a02-97f8-4d4f68104e51} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59558) (comment: 02366_direct_dictionary_dict_has.sql) (in query: DROP DICTIONARY test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:10:22.451123 [ 5310 ] {3f35f049-91ac-4a02-97f8-4d4f68104e51} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /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>&) @ 0x0000000011572b41 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 17. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:10:22.548406 [ 3240 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:23.069791 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:23.553970 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:23.921684 [ 4904 ] {f2da09c7-981c-45d1-9dce-66fd3e5aec0e} executeQuery: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv4(toIPv6('::afff:1.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 (&) [46], String&&) @ 0x00000000073b576b 4. /build/src/Functions/FunctionsConversion.cpp:0: 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&&) @ 0x0000000007284abc 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007280051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:23.926965 [ 4904 ] {f2da09c7-981c-45d1-9dce-66fd3e5aec0e} TCPHandler: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 (&) [46], String&&) @ 0x00000000073b576b 4. /build/src/Functions/FunctionsConversion.cpp:0: 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&&) @ 0x0000000007284abc 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007280051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:24.076411 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:24.514701 [ 4992 ] {a152a2a4-e656-4329-9f9c-4d1c2cc2434f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50932) (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.1 db,name literal' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:24.545046 [ 4992 ] {a152a2a4-e656-4329-9f9c-4d1c2cc2434f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:10:24.560631 [ 3093 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:24.660524 [ 4904 ] {1840f5a7-95ff-45d4-bb45-fbffeddcc4c0} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT cast('test' , 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:279: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000073b1a51 5. /build/src/Functions/FunctionsConversion.cpp:0: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x000000000711554b 6. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 7. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 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 @ 0x0000000007b68689 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:24.667268 [ 4904 ] {1840f5a7-95ff-45d4-bb45-fbffeddcc4c0} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:279: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000073b1a51 5. /build/src/Functions/FunctionsConversion.cpp:0: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x000000000711554b 6. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 7. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 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 @ 0x0000000007b68689 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:25.083722 [ 3314 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:25.567671 [ 3395 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:26.068836 [ 4904 ] {78d6b451-13ce-476c-ab2c-3169396ac9a6} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT IPv6StringToNum('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070cc53b 5. /build/src/Functions/FunctionsCodingIP.h:0: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070cb458 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070caad3 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&) @ 0x0000000011050d10 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 2025.09.25 21:10:26.081156 [ 4904 ] {78d6b451-13ce-476c-ab2c-3169396ac9a6} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070cc53b 5. /build/src/Functions/FunctionsCodingIP.h:0: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000070cb458 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070caad3 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&) @ 0x0000000011050d10 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 2025.09.25 21:10:26.089848 [ 3160 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:26.575078 [ 3279 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:27.181867 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:27.292948 [ 4904 ] {097497ae-3455-4bf4-a1ae-94ee1de66053} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv6('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000070d08eb 4. /build/src/IO/ReadHelpers.h:0: 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&&) @ 0x000000000728c8c9 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007288051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:27.308303 [ 4904 ] {097497ae-3455-4bf4-a1ae-94ee1de66053} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000070d08eb 4. /build/src/IO/ReadHelpers.h:0: 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&&) @ 0x000000000728c8c9 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007288051 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:10:27.581461 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:27.948329 [ 4904 ] {44c3b75c-28cf-4d9a-b22c-d9178541a57a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59600) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv6OrDefault('::ffff:127.0.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:27.954980 [ 4904 ] {44c3b75c-28cf-4d9a-b22c-d9178541a57a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:28.188352 [ 3463 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:28.588500 [ 3488 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:29.094791 [ 5326 ] {acc1f9ac-c23b-4b27-bfd0-ae70c00ca517} executeQuery: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42764) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE a (`number` UInt64, `x` MATERIALIZED x) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 3396, 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 = 536870912, compact_parts_max_bytes_to_buffer = 101279660, compact_parts_max_granules_to_buffer = 126, compact_parts_merge_max_bytes_to_prefetch_part = 33079114, merge_max_block_size = 4075, 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 = 28319453, concurrent_part_removal_threshold = 90, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 26523, primary_key_compress_block_size = 94285), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b62fc 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b690e 6. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7654 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 8. /build/src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000011882784 9. /build/contrib/llvm-project/libcxx/include/__tree:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011883a27 10. /build/src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df42e 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:10:29.099724 [ 5326 ] {acc1f9ac-c23b-4b27-bfd0-ae70c00ca517} TCPHandler: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b62fc 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b690e 6. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7654 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 8. /build/src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000011882784 9. /build/contrib/llvm-project/libcxx/include/__tree:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011883a27 10. /build/src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df42e 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:10:29.231583 [ 5326 ] {a8f0eed7-f0e3-434f-a5c0-a05f1c27b89c} executeQuery: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42764) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE foo (`i` Int32, `j` ALIAS j + 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 3396, 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 = 536870912, compact_parts_max_bytes_to_buffer = 101279660, compact_parts_max_granules_to_buffer = 126, compact_parts_merge_max_bytes_to_prefetch_part = 33079114, merge_max_block_size = 4075, 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 = 28319453, concurrent_part_removal_threshold = 90, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 26523, primary_key_compress_block_size = 94285), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b62fc 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b690e 6. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7804 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 8. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7654 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 10. /build/src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000011882784 11. /build/contrib/llvm-project/libcxx/include/__tree:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011883a27 12. /build/src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df42e 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 15. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:10:29.234822 [ 5326 ] {a8f0eed7-f0e3-434f-a5c0-a05f1c27b89c} TCPHandler: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b62fc 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b690e 6. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7804 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 8. /build/src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000118b7654 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000118b69f1 10. /build/src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000011882784 11. /build/contrib/llvm-project/libcxx/include/__tree:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011883a27 12. /build/src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000121df42e 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e162 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 15. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:10:29.267482 [ 3246 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:29.593202 [ 3149 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:30.287753 [ 3453 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:30.614766 [ 3337 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:30.632269 [ 8202 ] {09f38238-2eb2-4a30-8d69-162cead43d70} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): while reading column value at /var/lib/clickhouse/store/2f6/2f63b828-6015-4055-b109-8528019d347e/: While executing Log: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictGetOrNull('complex_key_dictionary'_String : 2, 'value'_String :: 3, tuple(__table1.number, 'key'_String) : 0) -> dictGetOrNull('complex_key_dictionary'_String, 'value'_String, tuple(__table1.number, 'key'_String)) Nullable(String) : 6'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59644) (comment: 01780_dict_get_or_null.sql) (in query: SELECT (number, 'key'), dictHas('complex_key_dictionary', (number, 'key')), dictGetOrNull('complex_key_dictionary', 'value', (number, 'key')), dictGetOrNull('complex_key_dictionary', 'value_nullable', (number, 'key')), dictGetOrNull('complex_key_dictionary', ('value', 'value_nullable'), (number, 'key')) FROM system.numbers LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:12: DB::CompressedReadBuffer::nextImpl() @ 0x0000000010ba3b3b 17. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 18. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d657f2 19. /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 @ 0x0000000010cd58d9 20. /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>>>&) @ 0x00000000124f61ae 21. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 22. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 28. /build/src/Dictionaries/DirectDictionary.cpp:347: DB::SourceFromQueryPipeline::generate() @ 0x000000000cbfa44b 29. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 30. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 31. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 2025.09.25 21:10:30.659875 [ 8202 ] {09f38238-2eb2-4a30-8d69-162cead43d70} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): while reading column value at /var/lib/clickhouse/store/2f6/2f63b828-6015-4055-b109-8528019d347e/: While executing Log: While executing SourceFromQueryPipeline: while executing 'FUNCTION dictGetOrNull('complex_key_dictionary'_String : 2, 'value'_String :: 3, tuple(__table1.number, 'key'_String) : 0) -> dictGetOrNull('complex_key_dictionary'_String, 'value'_String, tuple(__table1.number, 'key'_String)) Nullable(String) : 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:12: DB::CompressedReadBuffer::nextImpl() @ 0x0000000010ba3b3b 17. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 18. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d657f2 19. /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 @ 0x0000000010cd58d9 20. /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>>>&) @ 0x00000000124f61ae 21. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 22. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 28. /build/src/Dictionaries/DirectDictionary.cpp:347: DB::SourceFromQueryPipeline::generate() @ 0x000000000cbfa44b 29. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 30. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 31. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 2025.09.25 21:10:31.293806 [ 3120 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:31.623932 [ 3150 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:32.300061 [ 3211 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:32.427886 [ 5310 ] {9e3b423a-27ee-4afb-847a-7e7de82f8fc7} 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.10508.altinitytest (altinity build)) (from [::1]:42742) (comment: 02006_test_positional_arguments.sql) (in query: select x1, x2, x3 from test order by x3 limit 1 by x1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:10:32.439558 [ 5310 ] {9e3b423a-27ee-4afb-847a-7e7de82f8fc7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:10:32.633802 [ 3373 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:33.312402 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:33.639900 [ 3081 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:34.317342 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:34.647673 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:35.325201 [ 3007 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:35.652101 [ 3287 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:36.365943 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:36.654272 [ 3283 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:37.373728 [ 3207 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:37.669150 [ 3458 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:38.380221 [ 3309 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:38.676044 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:39.385900 [ 3157 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:39.684383 [ 3451 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:40.395890 [ 3090 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:40.697790 [ 3300 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:40.776845 [ 5310 ] {f2c025c3-f4b5-46c4-9fea-fc88d093468d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:39420) (comment: 01031_mutations_interpreter_and_context.sh) (in query: DROP DATABASE IF EXISTS test_zx4cs314 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:40.780323 [ 5310 ] {f2c025c3-f4b5-46c4-9fea-fc88d093468d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:40.884249 [ 7897 ] {42484e05-aeae-4392-9d52-71beb2842d38} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:39436) (comment: 01031_mutations_interpreter_and_context.sh) (in query: DROP DATABASE IF EXISTS test_zx4cs314 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:10:40.889944 [ 7897 ] {42484e05-aeae-4392-9d52-71beb2842d38} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:41.255674 [ 3593 ] {8c8ac5e9-e6f8-4c7f-9634-6464d359f8d3::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:41.266202 [ 3593 ] {8c8ac5e9-e6f8-4c7f-9634-6464d359f8d3::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:41.295957 [ 2926 ] {bdd2c0f6-c4db-497b-8900-235987854016} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.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.10508.altinitytest (altinity build)) (from [::1]:48506) (comment: 00699_materialized_view_mutations.sh) (in query: ALTER TABLE null_00699 DELETE WHERE x % 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&) @ 0x00000000128c1d4b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1c83 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bc9a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cb24 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:10:41.305781 [ 2926 ] {bdd2c0f6-c4db-497b-8900-235987854016} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&) @ 0x00000000128c1d4b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1c83 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bc9a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cb24 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:10:41.397733 [ 3253 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:41.701724 [ 3267 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:42.404588 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:42.708352 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:43.413732 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:43.713842 [ 3473 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:44.420014 [ 3194 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:44.720672 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:45.460839 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:45.725071 [ 3009 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:46.466248 [ 3173 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:46.730591 [ 3293 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:47.375276 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_29_72_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:47.472286 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:47.755576 [ 3189 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:48.483920 [ 3183 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:48.760768 [ 3260 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:49.486441 [ 3236 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:49.793564 [ 3067 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:50.492782 [ 3018 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:50.798243 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:51.135042 [ 4904 ] {27951f1f-f0cd-4716-b05e-a1b5595b84d6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03035_materialized_primary_key.sql) (in query: /* ddl_entry=query-0000000064 */ CREATE MATERIALIZED VIEW test_5.test_mv_pk UUID '74177c19-2c97-4862-958d-55260beeb446' TO INNER UUID '081ab8b7-eb42-4d87-b235-7a43a0fb1b65' (`value` String, `id` UInt64) ENGINE = MergeTree PRIMARY KEY value POPULATE AS SELECT value, id FROM test_5.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 24. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 25. /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&)>) @ 0x0000000011913de8 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 27. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 28. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 29. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 31. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 2025.09.25 21:10:51.168154 [ 4904 ] {27951f1f-f0cd-4716-b05e-a1b5595b84d6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51610) (comment: 03035_materialized_primary_key.sql) (in query: CREATE MATERIALIZED VIEW test_mv_pk ( value String, id UInt64 ) ENGINE=MergeTree PRIMARY KEY value POPULATE AS SELECT value, id FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 24. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 25. /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&)>) @ 0x0000000011913de8 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 27. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 28. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 29. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 31. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 2025.09.25 21:10:51.198447 [ 4904 ] {27951f1f-f0cd-4716-b05e-a1b5595b84d6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 24. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 25. /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&)>) @ 0x0000000011913de8 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 27. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 28. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 29. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 31. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 2025.09.25 21:10:51.499088 [ 3181 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:51.818773 [ 3048 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:52.505041 [ 3466 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:52.828454 [ 3359 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:53.518700 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:53.833934 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:53.917248 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_29_72_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:54.530716 [ 3333 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:54.819801 [ 4904 ] {hello} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58090) (comment: 00600_replace_running_query.sh) (in query: SELECT 1, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000011702c8a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:54.825048 [ 4904 ] {hello} DynamicQueryHandler: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000011702c8a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:54.837403 [ 3446 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:54.931707 [ 4665 ] {bb52afd5-5adf-4176-a3cf-4d498512ac67} executeQuery: Code: 716. DB::Exception: Partition 20240103 is not empty. (CANNOT_FORGET_PARTITION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51768) (comment: 02995_forget_partition.sh) (in query: alter table forget_partition forget partition '20240103';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/MergeTree/MergeTreeData.cpp:5035: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127beba4 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f168 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:10:54.933199 [ 4665 ] {bb52afd5-5adf-4176-a3cf-4d498512ac67} TCPHandler: Code: 716. DB::Exception: Partition 20240103 is not empty. (CANNOT_FORGET_PARTITION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/MergeTree/MergeTreeData.cpp:5035: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127beba4 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f168 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:10:54.995859 [ 7932 ] {42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51776) (in query: SELECT 2, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:10:54.997856 [ 4665 ] {13a4d4e2-a54b-4411-ab50-92f294b2d887} executeQuery: Code: 716. DB::Exception: Partition 20240203 is unknown. (CANNOT_FORGET_PARTITION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51768) (comment: 02995_forget_partition.sh) (in query: alter table forget_partition forget partition '20240203';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/StorageReplicatedMergeTree.cpp:7454: DB::StorageReplicatedMergeTree::forgetPartition(std::shared_ptr const&, std::shared_ptr) @ 0x00000000123feefa 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5319: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000127c32da 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f1d2 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:54.998395 [ 7932 ] {42} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:10:55.004056 [ 4665 ] {13a4d4e2-a54b-4411-ab50-92f294b2d887} TCPHandler: Code: 716. DB::Exception: Partition 20240203 is unknown. (CANNOT_FORGET_PARTITION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/StorageReplicatedMergeTree.cpp:7454: DB::StorageReplicatedMergeTree::forgetPartition(std::shared_ptr const&, std::shared_ptr) @ 0x00000000123feefa 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5319: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000127c32da 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f1d2 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:55.029619 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {da4b0f46-cb5e-4c3c-b2a1-86ffeaae2bb8::202509_1_80_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:55.536660 [ 3237 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:55.839351 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:56.543213 [ 3299 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:56.735608 [ 7932 ] {a87a1d5f-ef14-43bb-bfb8-f2d82d0fcfaf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51790) (comment: 00836_numbers_table_function_zero.sql) (in query: SELECT count() 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:56.743242 [ 7932 ] {a87a1d5f-ef14-43bb-bfb8-f2d82d0fcfaf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=763, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:10:56.846186 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:57.551577 [ 3178 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:57.852579 [ 3162 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:58.044489 [ 4904 ] {42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53288) (comment: 00600_replace_running_query.sh) (in query: SELECT 3, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000011702c8a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:10:58.045824 [ 4904 ] {42} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000011702c8a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:10:58.554116 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:58.858204 [ 3480 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:59.556961 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:10:59.865089 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:00.366371 [ 4665 ] {cfd217c8-d66c-40bb-b3d6-5ac1c1e1bb6c} DynamicQueryHandler: Code: 271. DB::Exception: Too large uncompressed size: 4294967295. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/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 int&) @ 0x000000001055f18b 4. /build/src/Compression/CompressionCodecMultiple.cpp:0: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000010bb3ea5 5. /build/src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000010bd37da 6. /build/src/Compression/CompressedReadBuffer.cpp:13: DB::CompressedReadBuffer::nextImpl() @ 0x0000000010ba3b91 7. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 8. /build/src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x00000000106ea319 9. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 10. /build/src/IO/ConcatReadBuffer.h:73: DB::ConcatReadBuffer::nextImpl() @ 0x00000000110bac76 11. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 12. /build/src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119134a5 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:00.533258 [ 7932 ] {bf01bec7-0d80-4909-8613-e2c395ecf82e} DynamicQueryHandler: Code: 246. DB::Exception: Wrong data for compression codec NONE: source_size (278) != uncompressed_size (33686018). (CORRUPTED_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 int&, unsigned int&) @ 0x000000000ebd418b 4. /build/src/Compression/CompressionCodecNone.cpp:33: DB::CompressionCodecNone::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000010baf8c3 5. /build/src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000010bd37da 6. /build/src/Compression/CompressionCodecMultiple.cpp:115: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000010bb3bac 7. /build/src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000010bd37da 8. /build/src/Compression/CompressedReadBuffer.cpp:13: DB::CompressedReadBuffer::nextImpl() @ 0x0000000010ba3b91 9. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 10. /build/src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x00000000106ea319 11. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 12. /build/src/IO/ConcatReadBuffer.h:73: DB::ConcatReadBuffer::nextImpl() @ 0x00000000110bac76 13. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 14. /build/src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119134a5 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:00.560490 [ 3179 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:00.614123 [ 2929 ] {b7cd3275-e207-4eb7-9314-0f9803bdad0a} executeQuery: Code: 44. DB::Exception: Sorting key cannot contain constants. (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53318) (comment: 02679_query_parameters_dangling_pointer.sql) (in query: CREATE TABLE test.xxx (`a` Int64) ENGINE = MergeTree ORDER BY 'a' SETTINGS index_granularity = 29636, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 218513494, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 28504373, merge_max_block_size = 17467, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 10, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 29549407, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 10342, primary_key_compress_block_size = 72465), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001277ec60 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277ddf4 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000012778710 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775dc 8. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 9. /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>&&) @ 0x0000000012a754d0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 11. /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 @ 0x00000000122534a7 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:00.655613 [ 2929 ] {b7cd3275-e207-4eb7-9314-0f9803bdad0a} TCPHandler: Code: 44. DB::Exception: Sorting key cannot contain constants. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001277ec60 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277ddf4 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000012778710 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775dc 8. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 9. /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>&&) @ 0x0000000012a754d0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 11. /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 @ 0x00000000122534a7 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:00.867387 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:01.564759 [ 3034 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:01.873134 [ 3417 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:02.011632 [ 8473 ] {40694193-3249-4024-ac32-5a2d73efee9f} executeQuery: Code: 46. DB::Exception: Function with name 'c23ount' does not exist. In scope SELECT c23ount(*) FROM system.functions. Maybe you meant: ['count']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53344) (comment: 00834_hints_for_type_function_typos.sh) (in query: select c23ount(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:02.029786 [ 8473 ] {40694193-3249-4024-ac32-5a2d73efee9f} TCPHandler: Code: 46. DB::Exception: Function with name 'c23ount' does not exist. In scope SELECT c23ount(*) FROM system.functions. Maybe you meant: ['count']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:02.510469 [ 7604 ] {78e68ac1-f80d-4eda-b411-af62d2bab09f} executeQuery: Code: 46. DB::Exception: Function with name 'cunt' does not exist. In scope SELECT cunt(*) FROM system.functions. Maybe you meant: ['count','CAST']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53358) (comment: 00834_hints_for_type_function_typos.sh) (in query: select cunt(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:02.515684 [ 7604 ] {78e68ac1-f80d-4eda-b411-af62d2bab09f} TCPHandler: Code: 46. DB::Exception: Function with name 'cunt' does not exist. In scope SELECT cunt(*) FROM system.functions. Maybe you meant: ['count','CAST']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:02.567034 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:02.876460 [ 3225 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:03.246699 [ 2929 ] {f497bc9a-94ff-4f0b-b791-2dcee2ed9184} executeQuery: Code: 46. DB::Exception: Function with name 'positin' does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53372) (comment: 00834_hints_for_type_function_typos.sh) (in query: select positin(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:03.263679 [ 2929 ] {f497bc9a-94ff-4f0b-b791-2dcee2ed9184} TCPHandler: Code: 46. DB::Exception: Function with name 'positin' does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:03.576663 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:03.893200 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:03.901453 [ 8473 ] {c66a5131-566a-4a52-9a12-29d6b870a0bb} executeQuery: Code: 46. DB::Exception: Function with name 'POSITIO' does not exist. In scope SELECT POSITIO(*) FROM system.functions. Maybe you meant: ['position']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53400) (comment: 00834_hints_for_type_function_typos.sh) (in query: select POSITIO(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:03.957503 [ 8473 ] {c66a5131-566a-4a52-9a12-29d6b870a0bb} TCPHandler: Code: 46. DB::Exception: Function with name 'POSITIO' does not exist. In scope SELECT POSITIO(*) FROM system.functions. Maybe you meant: ['position']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:04.564371 [ 8473 ] {83954241-b0d4-476e-8054-708eded8ad29} executeQuery: Code: 46. DB::Exception: Function with name 'fount' does not exist. In scope SELECT fount(*) FROM system.functions. Maybe you meant: ['count','round']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53422) (comment: 00834_hints_for_type_function_typos.sh) (in query: select fount(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:04.577565 [ 8473 ] {83954241-b0d4-476e-8054-708eded8ad29} TCPHandler: Code: 46. DB::Exception: Function with name 'fount' does not exist. In scope SELECT fount(*) FROM system.functions. Maybe you meant: ['count','round']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:04.579529 [ 3084 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:04.895478 [ 3446 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:05.247566 [ 2929 ] {bb350c89-47b0-4767-87e9-0d9f9957d270} 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.10508.altinitytest (altinity build)) (from [::1]:53384) (comment: 02200_use_skip_indexes.sql) (in query: SELECT * FROM data_02200 WHERE value = 1 SETTINGS use_skip_indexes=0, max_rows_to_read=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.262484 [ 2929 ] {bb350c89-47b0-4767-87e9-0d9f9957d270} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.268090 [ 7604 ] {84935325-9c49-4352-a63e-2879002ce8ed} executeQuery: Code: 46. DB::Exception: Function with name 'positin' does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53436) (comment: 00834_hints_for_type_function_typos.sh) (in query: select positin(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.286016 [ 7604 ] {84935325-9c49-4352-a63e-2879002ce8ed} TCPHandler: Code: 46. DB::Exception: Function with name 'positin' does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.589549 [ 3146 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:05.894001 [ 7604 ] {fae8e993-b8b9-4787-8436-d78d59e97399} executeQuery: Code: 46. DB::Exception: Function with name 'pov' does not exist. In scope SELECT pov(*) FROM system.functions. Maybe you meant: ['pow']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53450) (comment: 00834_hints_for_type_function_typos.sh) (in query: select pov(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.903549 [ 7604 ] {fae8e993-b8b9-4787-8436-d78d59e97399} TCPHandler: Code: 46. DB::Exception: Function with name 'pov' does not exist. In scope SELECT pov(*) FROM system.functions. Maybe you meant: ['pow']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:05.906902 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:06.462263 [ 2929 ] {b8983485-9c22-48ab-93d8-525a69295fae} executeQuery: Code: 46. DB::Exception: Function with name 'getColumnStructure' does not exist. In scope SELECT getColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53468) (comment: 00834_hints_for_type_function_typos.sh) (in query: select getColumnStructure('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:06.466531 [ 2929 ] {b8983485-9c22-48ab-93d8-525a69295fae} TCPHandler: Code: 46. DB::Exception: Function with name 'getColumnStructure' does not exist. In scope SELECT getColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:06.555337 [ 3588 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bb3dcfd6-a01b-47b1-9aaf-cf887b88b4e1::202509_1_57_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:06.602002 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:06.911884 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:07.003231 [ 2929 ] {3265c0b5-ba56-4d39-98f1-07cbcfc22097} executeQuery: Code: 46. DB::Exception: Function with name 'gutColumnStructure' does not exist. In scope SELECT gutColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49470) (comment: 00834_hints_for_type_function_typos.sh) (in query: select gutColumnStructure('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:07.014261 [ 2929 ] {3265c0b5-ba56-4d39-98f1-07cbcfc22097} TCPHandler: Code: 46. DB::Exception: Function with name 'gutColumnStructure' does not exist. In scope SELECT gutColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:07.575013 [ 2929 ] {c9326d70-25f5-4be7-b357-6de9e69e2743} executeQuery: Code: 46. DB::Exception: Function with name 'gupColumnStructure' does not exist. In scope SELECT gupColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49476) (comment: 00834_hints_for_type_function_typos.sh) (in query: select gupColumnStructure('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:07.589934 [ 2929 ] {c9326d70-25f5-4be7-b357-6de9e69e2743} TCPHandler: Code: 46. DB::Exception: Function with name 'gupColumnStructure' does not exist. In scope SELECT gupColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:07.609004 [ 3174 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:07.916867 [ 3011 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:08.071748 [ 2929 ] {5215baae-f1b1-4e7a-bba5-13ce64a223ad} executeQuery: Code: 46. DB::Exception: Function with name 'provideColumnStructure' does not exist. In scope SELECT provideColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49506) (comment: 00834_hints_for_type_function_typos.sh) (in query: select provideColumnStructure('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:08.081148 [ 2929 ] {5215baae-f1b1-4e7a-bba5-13ce64a223ad} TCPHandler: Code: 46. DB::Exception: Function with name 'provideColumnStructure' does not exist. In scope SELECT provideColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:08.616434 [ 2989 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:08.907392 [ 2929 ] {a6db052e-5214-4022-bca5-8b173ef85b63} executeQuery: Code: 46. DB::Exception: Function with name 'multisearchallposicionutf7' does not exist. In scope SELECT multisearchallposicionutf7('abc'). Maybe you meant: ['multiSearchAllPositionsUTF8','multiSearchAllPositions']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49526) (comment: 00834_hints_for_type_function_typos.sh) (in query: select multisearchallposicionutf7('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:08.923913 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:08.931468 [ 2929 ] {a6db052e-5214-4022-bca5-8b173ef85b63} TCPHandler: Code: 46. DB::Exception: Function with name 'multisearchallposicionutf7' does not exist. In scope SELECT multisearchallposicionutf7('abc'). Maybe you meant: ['multiSearchAllPositionsUTF8','multiSearchAllPositions']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:09.580792 [ 2929 ] {1a635d12-41df-46e8-8579-3816996744eb} executeQuery: Code: 46. DB::Exception: Function with name 'multisearchallposicionutf7casesensitive' does not exist. In scope SELECT multisearchallposicionutf7casesensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49540) (comment: 00834_hints_for_type_function_typos.sh) (in query: select multisearchallposicionutf7casesensitive('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:09.601491 [ 2929 ] {1a635d12-41df-46e8-8579-3816996744eb} TCPHandler: Code: 46. DB::Exception: Function with name 'multisearchallposicionutf7casesensitive' does not exist. In scope SELECT multisearchallposicionutf7casesensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAllPositionsCaseInsensitiveUTF8']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:09.622970 [ 3354 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:09.926371 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:10.287351 [ 7902 ] {bd0430e9-3f7a-4663-89d0-9f4c87faa970} executeQuery: Code: 46. DB::Exception: Function with name 'multiSearchAllposicionutf7sensitive' does not exist. In scope SELECT multiSearchAllposicionutf7sensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAnyCaseInsensitive']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49560) (comment: 00834_hints_for_type_function_typos.sh) (in query: select multiSearchAllposicionutf7sensitive('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:10.312802 [ 7902 ] {bd0430e9-3f7a-4663-89d0-9f4c87faa970} TCPHandler: Code: 46. DB::Exception: Function with name 'multiSearchAllposicionutf7sensitive' does not exist. In scope SELECT multiSearchAllposicionutf7sensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAnyCaseInsensitive']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:10.636352 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:10.934353 [ 3188 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:11.104598 [ 7902 ] {d23fd741-8346-4739-b01a-9caa1a09747e} executeQuery: Code: 46. DB::Exception: Function with name 'multiSearchAllPosicionSensitiveUTF8' does not exist. In scope SELECT multiSearchAllPosicionSensitiveUTF8('abc'). Maybe you meant: ['multiSearchAnyCaseInsensitiveUTF8','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49572) (comment: 00834_hints_for_type_function_typos.sh) (in query: select multiSearchAllPosicionSensitiveUTF8('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:11.122309 [ 7902 ] {d23fd741-8346-4739-b01a-9caa1a09747e} TCPHandler: Code: 46. DB::Exception: Function with name 'multiSearchAllPosicionSensitiveUTF8' does not exist. In scope SELECT multiSearchAllPosicionSensitiveUTF8('abc'). Maybe you meant: ['multiSearchAnyCaseInsensitiveUTF8','multiSearchAllPositionsCaseInsensitiveUTF8']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&&) @ 0x000000000cb8352b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053029 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:11.641839 [ 3358 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:11.757988 [ 7902 ] {fbe885a7-f089-4b14-bb5b-c4b405dc5f8c} executeQuery: Code: 46. DB::Exception: Unknown table function numberss. Maybe you meant: ['numbers','numbers_mt']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49584) (comment: 00834_hints_for_type_function_typos.sh) (in query: select * FROM numberss(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dc13 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:11.776376 [ 7902 ] {fbe885a7-f089-4b14-bb5b-c4b405dc5f8c} TCPHandler: Code: 46. DB::Exception: Unknown table function numberss. Maybe you meant: ['numbers','numbers_mt']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dc13 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:11.941279 [ 2996 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:12.431560 [ 7902 ] {fa91dca4-0f10-4f44-ac05-073587842c09} executeQuery: Code: 46. DB::Exception: Unknown table function anothernumbers. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49590) (comment: 00834_hints_for_type_function_typos.sh) (in query: select * FROM anothernumbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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) @ 0x000000001103dac1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:12.451175 [ 7902 ] {fa91dca4-0f10-4f44-ac05-073587842c09} TCPHandler: Code: 46. DB::Exception: Unknown table function anothernumbers. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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) @ 0x000000001103dac1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:12.648345 [ 2965 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:12.947591 [ 3274 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:13.264074 [ 7902 ] {89a73aab-f4f1-44be-b7b7-849ff8f89019} executeQuery: Code: 46. DB::Exception: Unknown table function mynumbers. Maybe you meant: ['numbers']. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49594) (comment: 00834_hints_for_type_function_typos.sh) (in query: select * FROM mynumbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dc13 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:13.285311 [ 7902 ] {89a73aab-f4f1-44be-b7b7-849ff8f89019} TCPHandler: Code: 46. DB::Exception: Unknown table function mynumbers. Maybe you meant: ['numbers']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dc13 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:13.654680 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:13.954314 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:14.530288 [ 7902 ] {49a58a48-c131-48bc-aa39-dabf71274654} executeQuery: Code: 56. DB::Exception: Unknown table engine MergeTre. Maybe you meant: ['MergeTree']. (UNKNOWN_STORAGE) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00834_hints_for_type_function_typos.sh) (in query: /* ddl_entry=query-0000000065 */ CREATE TABLE test_5.stored_aggregates UUID '62deb496-87d1-4b11-bac6-d43ce07ed8a5' (`d` Date, `Uniq` AggregateFunction(uniq, UInt64)) ENGINE = MergeTre(d, d, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x00000000084e1c4b 4. /build/src/Storages/StorageFactory.cpp:0: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000122542ed 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:14.556277 [ 7902 ] {49a58a48-c131-48bc-aa39-dabf71274654} executeQuery: Code: 56. DB::Exception: Unknown table engine MergeTre. Maybe you meant: ['MergeTree']. (UNKNOWN_STORAGE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49608) (comment: 00834_hints_for_type_function_typos.sh) (in query: CREATE TABLE stored_aggregates (d Date, Uniq AggregateFunction(uniq, UInt64)) ENGINE = MergeTre(d, d, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x00000000084e1c4b 4. /build/src/Storages/StorageFactory.cpp:0: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000122542ed 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:14.567816 [ 7902 ] {49a58a48-c131-48bc-aa39-dabf71274654} TCPHandler: Code: 56. DB::Exception: Unknown table engine MergeTre. Maybe you meant: ['MergeTree']. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x00000000084e1c4b 4. /build/src/Storages/StorageFactory.cpp:0: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000122542ed 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 11. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 13. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:11:14.658380 [ 2979 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:14.974215 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:15.536276 [ 8473 ] {a3b31f56-a834-4496-805a-fd70b5f7630e} executeQuery: Code: 50. DB::Exception: Unknown data type family: AgregateFunction. Maybe you meant: ['AggregateFunction']. (UNKNOWN_TYPE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49654) (comment: 00834_hints_for_type_function_typos.sh) (in query: CREATE TABLE stored_aggregates (d Date, Uniq AgregateFunction(uniq, UInt64)) ENGINE = MergeTree(d, d, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeFactory.cpp:0: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000010c36711 5. /build/src/DataTypes/DataTypeFactory.cpp:138: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3600d 6. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35abe 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e316 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 9. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:11:15.554086 [ 8473 ] {a3b31f56-a834-4496-805a-fd70b5f7630e} TCPHandler: Code: 50. DB::Exception: Unknown data type family: AgregateFunction. Maybe you meant: ['AggregateFunction']. (UNKNOWN_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeFactory.cpp:0: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000010c36711 5. /build/src/DataTypes/DataTypeFactory.cpp:138: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3600d 6. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35abe 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e316 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 9. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:11:15.667510 [ 3413 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:15.981208 [ 3345 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:16.407054 [ 7598 ] {d8578d31-2d72-4b0d-b823-117baebfcfb5} executeQuery: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49690) (comment: 02292_create_function_validate.sql) (in query: create function foo as x -- { serverError UNSUPPORTED_METHOD } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x00000000132337bd 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000013233bc8 6. /build/src/QueryPipeline/BlockIO.h:14: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000001197aabd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:16.427217 [ 7598 ] {d8578d31-2d72-4b0d-b823-117baebfcfb5} TCPHandler: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x00000000132337bd 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000013233bc8 6. /build/src/QueryPipeline/BlockIO.h:14: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000001197aabd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:16.671813 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:16.857223 [ 5310 ] {ed96d775-6f15-466e-b641-04a747b3fe79} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37422) (comment: 01455_opentelemetry_distributed.sh) (in query: SELECT count() AS `initial query spans with proper parent` FROM `system`.`opentelemetry_span_log` AS `__table1` WHERE (`__table1`.`trace_id` = _CAST('a1645d8a-f190-ecf4-0b0d-4cc6e4b94b42', 'String')) AND (`__table1`.`operation_name` = 'query') AND (`__table1`.`parent_span_id` IN (SELECT `__table1`.`span_id` AS `span_id` FROM `system`.`opentelemetry_span_log` AS `__table1` WHERE (`__table1`.`trace_id` = _CAST('a1645d8a-f190-ecf4-0b0d-4cc6e4b94b42', 'String')) AND (`__table1`.`parent_span_id` = _CAST(115, '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:16.868312 [ 5310 ] {ed96d775-6f15-466e-b641-04a747b3fe79} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:16.882990 [ 7898 ] {fc1f5a86-ca1c-44c4-b5d2-b640ee11164b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51680) (comment: 01455_opentelemetry_distributed.sh) (in query: -- Also check that the initial query span in ClickHouse has proper parent span. -- the first span should be child of input trace context -- the 2nd span should be the 'query' span select count(*) "initial query spans with proper parent" from system.opentelemetry_span_log where trace_id = UUIDNumToString(toFixedString(unhex('a1645d8af190ecf40b0d4cc6e4b94b42'), 16)) and operation_name = 'query' and parent_span_id in ( select span_id from system.opentelemetry_span_log where trace_id = UUIDNumToString(toFixedString(unhex('a1645d8af190ecf40b0d4cc6e4b94b42'), 16)) and parent_span_id = reinterpretAsUInt64(unhex('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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:11:16.890698 [ 7898 ] {fc1f5a86-ca1c-44c4-b5d2-b640ee11164b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:11:16.984505 [ 3031 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:17.685727 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:17.989172 [ 3217 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:18.416686 [ 4992 ] {64685e7b-9b45-46d0-9fbe-6d3b1715fcc6} executeQuery: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57444) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT ) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154fcea 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 6. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.432841 [ 4992 ] {64685e7b-9b45-46d0-9fbe-6d3b1715fcc6} TCPHandler: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154fcea 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155051d 6. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.690288 [ 3017 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:18.787320 [ 7598 ] {c25f90c2-1f2b-425d-bd85-81b4a929c1e1} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000127791c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.789750 [ 7598 ] {c25f90c2-1f2b-425d-bd85-81b4a929c1e1} TCPHandler: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000127791c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.888433 [ 7598 ] {60431d99-680e-47a6-89ab-45e7be7e0b66} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x000000001277fcf4 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778f35 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.890359 [ 7598 ] {60431d99-680e-47a6-89ab-45e7be7e0b66} TCPHandler: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x000000001277fcf4 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778f35 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:18.999585 [ 3184 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:19.157876 [ 7598 ] {46f852ff-1170-4e2a-9bb8-647476c8183c} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012779592 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.160550 [ 7598 ] {46f852ff-1170-4e2a-9bb8-647476c8183c} TCPHandler: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012779592 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.520448 [ 7598 ] {8ea8b821-9bb6-4745-b135-b69e34d632cd} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN ver 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6fa7 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.524472 [ 7598 ] {8ea8b821-9bb6-4745-b135-b69e34d632cd} TCPHandler: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a6fa7 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.692371 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:19.727415 [ 5310 ] {eaa38626-fcd0-4847-a508-4c3eedacf8ca} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57468) (comment: 02922_respect_nulls_Nullable.sql) (in query: -- { echoOn } Select anyOrNull(tp) FROM (Select (number, number) as tp 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000010c5a9ec 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000010258458 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025721b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000010257038 8. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.cpp:42: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010256fa9 9. /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 @ 0x00000000104bc717 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 31. ? @ 0x00007fd96814bac3 2025.09.25 21:11:19.748306 [ 5310 ] {eaa38626-fcd0-4847-a508-4c3eedacf8ca} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000010c5a9ec 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000010258458 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025721b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000010257038 8. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.cpp:42: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010256fa9 9. /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 @ 0x00000000104bc717 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 31. ? @ 0x00007fd96814bac3 2025.09.25 21:11:19.772877 [ 7598 ] {1f04efe0-bcc6-47ca-9598-744074ae3fca} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.780418 [ 7598 ] {1f04efe0-bcc6-47ca-9598-744074ae3fca} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.895574 [ 5310 ] {e06a1262-ed5f-4865-b88c-75e8a0ab37f3} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57468) (comment: 02922_respect_nulls_Nullable.sql) (in query: Select anyOrNull(tp) FROM (Select (number, number) as tp 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000010c5a9ec 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000010258458 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025721b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000010257038 8. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.cpp:42: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010256fa9 9. /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 @ 0x00000000104bc717 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 31. ? @ 0x00007fd96814bac3 2025.09.25 21:11:19.900299 [ 5310 ] {e06a1262-ed5f-4865-b88c-75e8a0ab37f3} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000010c5a9ec 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000010258458 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025721b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000010257038 8. /build/src/AggregateFunctions/Combinators/AggregateFunctionOrFill.cpp:42: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010256fa9 9. /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 @ 0x00000000104bc717 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 31. ? @ 0x00007fd96814bac3 2025.09.25 21:11:19.911975 [ 7598 ] {8412baf0-9260-4230-ac5a-56fb1e6cd9d9} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.914431 [ 7598 ] {8412baf0-9260-4230-ac5a-56fb1e6cd9d9} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.969080 [ 7598 ] {7c87baab-dafd-4df1-b75c-b273f1127a15} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:19.975857 [ 7598 ] {7c87baab-dafd-4df1-b75c-b273f1127a15} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.001850 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:20.199857 [ 7598 ] {95950d1e-f908-4909-bcbd-0f6a9d5a0fdd} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a672e 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.201763 [ 7598 ] {95950d1e-f908-4909-bcbd-0f6a9d5a0fdd} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a672e 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.212317 [ 4992 ] {bfbf563e-0139-4e6a-8e98-51b3c7a993a0} executeQuery: Code: 57. DB::Exception: Table test_tfaz5j27.ignore_auto_increment already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57444) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: CREATE TABLE ignore_auto_increment ( di DEFAULT 1, id int AUTO_INCREMENT, s String EPHEMERAL ) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.214006 [ 4992 ] {bfbf563e-0139-4e6a-8e98-51b3c7a993a0} TCPHandler: Code: 57. DB::Exception: Table test_tfaz5j27.ignore_auto_increment 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.262682 [ 7598 ] {d2194410-1c32-4212-9871-75872d997b67} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing DROP COLUMN is_deleted;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aad89 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.280357 [ 7598 ] {d2194410-1c32-4212-9871-75872d997b67} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aad89 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.422343 [ 8473 ] {494578ca-7d04-428c-8764-9689626f312d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37366) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: DROP DATABASE IF EXISTS test_tfaz5j27 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.427359 [ 7598 ] {b902c96c-f0c8-44c1-8fa5-7880e510ae97} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing RENAME COLUMN ver TO ver2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a667b 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.431343 [ 8473 ] {494578ca-7d04-428c-8764-9689626f312d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:20.441665 [ 7598 ] {b902c96c-f0c8-44c1-8fa5-7880e510ae97} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a667b 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.641807 [ 7598 ] {9d14d6c7-13d8-4e54-a11b-f35b4fbff57b} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE replacing RENAME COLUMN is_deleted TO is_deleted2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aade5 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.645224 [ 7598 ] {9d14d6c7-13d8-4e54-a11b-f35b4fbff57b} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aade5 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.694334 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:20.876817 [ 7598 ] {58895864-183a-4ae0-b2d9-196817dc2a96} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277f97f 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:20.880355 [ 7598 ] {58895864-183a-4ae0-b2d9-196817dc2a96} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277f97f 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.008864 [ 3280 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:21.059370 [ 7598 ] {c6891e05-72fb-483b-a3ad-9446a453451e} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277f97f 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.087518 [ 7598 ] {c6891e05-72fb-483b-a3ad-9446a453451e} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010e285eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277f97f 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.298446 [ 7598 ] {08eb8088-b9e7-4451-8896-0c2c9fd57c96} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277fa5b 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.304893 [ 7598 ] {08eb8088-b9e7-4451-8896-0c2c9fd57c96} TCPHandler: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x000000001277fa5b 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000012778891 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 7. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 8. /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>&&) @ 0x0000000012a754d0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 10. /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 @ 0x00000000122534a7 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.580034 [ 5310 ] {a2a5de1a-f22a-4232-991a-af87d2c5482d} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57468) (comment: 02922_respect_nulls_Nullable.sql) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsOrNullState(number) as t FROM numbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010246136 5. /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 @ 0x00000000104bc717 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 @ 0x00000000104bb8d4 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.595669 [ 5310 ] {a2a5de1a-f22a-4232-991a-af87d2c5482d} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010246136 5. /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 @ 0x00000000104bc717 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 @ 0x00000000104bb8d4 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.687916 [ 7598 ] {c2a69cb8-684f-4d18-bbf2-c2ca6ded9d09} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing MODIFY COLUMN sign 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.693941 [ 7598 ] {c2a69cb8-684f-4d18-bbf2-c2ca6ded9d09} TCPHandler: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x00000000128095eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aae52 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.699301 [ 5310 ] {adb87bf4-be8c-42ba-80cb-07e739725ea4} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57468) (comment: 02922_respect_nulls_Nullable.sql) (in query: SELECT first_value_respect_nullsOrNullMerge(t) FROM (Select first_value_respect_nullsState(number) as t FROM numbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010246136 5. /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 @ 0x00000000104bc717 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 @ 0x00000000104bb8d4 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.701567 [ 3277 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:21.707804 [ 5310 ] {adb87bf4-be8c-42ba-80cb-07e739725ea4} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000010246136 5. /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 @ 0x00000000104bc717 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 @ 0x00000000104bb8d4 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.872439 [ 7598 ] {e78d3460-1406-4ecc-855d-e2ca3bfccce7} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing DROP COLUMN sign;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aad89 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:21.874853 [ 7598 ] {e78d3460-1406-4ecc-855d-e2ca3bfccce7} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aad89 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.017016 [ 3104 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:22.068148 [ 7598 ] {c3f6b715-94c3-4ffc-9121-24f8fb411151} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing RENAME COLUMN sign TO sign2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aade5 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.070208 [ 7598 ] {c3f6b715-94c3-4ffc-9121-24f8fb411151} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x00000000128096cb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aade5 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.170029 [ 7598 ] {898e2ada-a3e3-47f7-bd54-b4f3ff36367a} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: ALTER TABLE collapsing MODIFY COLUMN sign MODIFY SETTING max_compress_block_size = 123456;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x000000001280950b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:889: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aacd1 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.177728 [ 7598 ] {898e2ada-a3e3-47f7-bd54-b4f3ff36367a} TCPHandler: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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 const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x000000001280950b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:889: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x00000000127aacd1 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3367: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4630 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.420091 [ 7598 ] {5ae1c692-156a-4815-a721-2c733031cee4} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57462) (comment: 03093_special_column_errors.sql) (in query: CREATE TABLE versioned_collapsing_wrong (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 2349, min_bytes_for_wide_part = 477301830, 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 = 80157452, compact_parts_max_bytes_to_buffer = 324766906, compact_parts_max_granules_to_buffer = 117, compact_parts_merge_max_bytes_to_prefetch_part = 4827085, merge_max_block_size = 2970, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9308475412, index_granularity_bytes = 18104161, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 57208, primary_key_compress_block_size = 59880), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000127795fd 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.423754 [ 7598 ] {5ae1c692-156a-4815-a721-2c733031cee4} TCPHandler: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000127795fd 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775ec 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:22.703853 [ 3451 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:23.023577 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:23.609121 [ 5326 ] {906ae0a0-434b-4934-a18d-4d0baec40cd5} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57550) (comment: 02989_variant_comparison.sql) (in query: create table test (v1 Variant(String, UInt64, Array(UInt32)), v2 Variant(String, UInt64, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:23.631623 [ 5326 ] {906ae0a0-434b-4934-a18d-4d0baec40cd5} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:23.705668 [ 3487 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:24.030090 [ 3328 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:24.707836 [ 3009 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:25.032615 [ 3478 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:25.714505 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:26.042493 [ 3140 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:26.743045 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:27.045816 [ 3079 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:27.460718 [ 7934 ] {face76ec-8536-4835-9cda-f868a7c0fd94} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53482) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000010c918f9 4. /build/src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000010c90611 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000010cebced 6. /build/src/IO/BufferBase.h:41: COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000072f58e9 7. /build/src/DataTypes/IDataType.h:0: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000072edcae 8. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000072e9308 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&) @ 0x0000000011050d10 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:11:27.483011 [ 7934 ] {face76ec-8536-4835-9cda-f868a7c0fd94} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000010c918f9 4. /build/src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000010c90611 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000010cebced 6. /build/src/IO/BufferBase.h:41: COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000072f58e9 7. /build/src/DataTypes/IDataType.h:0: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000072edcae 8. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000072e9308 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&) @ 0x0000000011050d10 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:11:27.578138 [ 7934 ] {1977ae76-a4eb-4cab-9c9a-d6ea3964fc6f} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53482) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000010c918f9 4. /build/src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000010c90611 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000010cebced 6. /build/src/IO/BufferBase.h:41: COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000072f58e9 7. /build/src/DataTypes/IDataType.h:0: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000072edcae 8. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000072e9308 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&) @ 0x0000000011050d10 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:11:27.593531 [ 7934 ] {1977ae76-a4eb-4cab-9c9a-d6ea3964fc6f} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000010c918f9 4. /build/src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000010c90611 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000010cebced 6. /build/src/IO/BufferBase.h:41: COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000072f58e9 7. /build/src/DataTypes/IDataType.h:0: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000072edcae 8. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000072e9308 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&) @ 0x0000000011050d10 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:11:27.749483 [ 3091 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:28.054864 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:28.616896 [ 7934 ] {26732e44-e1be-4dc6-8705-a222678f0306} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53482) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '1E-9' AS x, toDecimal32(x, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000010c2a373 5. /build/src/DataTypes/DataTypesDecimal.h:40: std::shared_ptr>> std::allocate_shared[abi:v15007]>, std::allocator>>, unsigned long const&, unsigned long&, void>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000010c913c2 6. /build/src/DataTypes/DataTypesDecimal.cpp:351: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000010c901bf 7. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, 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&) @ 0x00000000072f7436 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000072e9fbb 9. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 10. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 11. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110501ab 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:11:28.622753 [ 7934 ] {26732e44-e1be-4dc6-8705-a222678f0306} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-9' AS x, toDecimal32(x, 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000010c2a373 5. /build/src/DataTypes/DataTypesDecimal.h:40: std::shared_ptr>> std::allocate_shared[abi:v15007]>, std::allocator>>, unsigned long const&, unsigned long&, void>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000010c913c2 6. /build/src/DataTypes/DataTypesDecimal.cpp:351: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000010c901bf 7. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, 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&) @ 0x00000000072f7436 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000072e9fbb 9. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 10. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 11. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110501ab 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:11:28.655543 [ 7934 ] {f1568754-3f64-4c07-baba-4bf5016760d0} executeQuery: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53482) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '1E-10' AS x, toDecimal32(x, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000010c2a373 5. /build/src/DataTypes/DataTypesDecimal.h:40: std::shared_ptr>> std::allocate_shared[abi:v15007]>, std::allocator>>, unsigned long const&, unsigned long&, void>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000010c913c2 6. /build/src/DataTypes/DataTypesDecimal.cpp:351: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000010c901bf 7. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, 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&) @ 0x00000000072f7436 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000072e9fbb 9. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 10. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 11. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110501ab 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:11:28.659296 [ 7934 ] {f1568754-3f64-4c07-baba-4bf5016760d0} TCPHandler: Code: 69. DB::Exception: Scale 10 is out of bounds (max scale: 9): In scope SELECT '1E-10' AS x, toDecimal32(x, 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000010c2a373 5. /build/src/DataTypes/DataTypesDecimal.h:40: std::shared_ptr>> std::allocate_shared[abi:v15007]>, std::allocator>>, unsigned long const&, unsigned long&, void>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000010c913c2 6. /build/src/DataTypes/DataTypesDecimal.cpp:351: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000010c901bf 7. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, 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&) @ 0x00000000072f7436 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000072e9fbb 9. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 10. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 11. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110501ab 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:11:28.762744 [ 3198 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:29.101924 [ 3405 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:29.765484 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:30.108276 [ 3330 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:30.768334 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:31.112698 [ 3119 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:31.770439 [ 3164 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:32.118550 [ 3172 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:32.774964 [ 3198 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:33.122757 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:33.777279 [ 3067 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:34.129426 [ 3391 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:34.579318 [ 5326 ] {84ef1d5f-e2f3-41ce-bfa5-dac5e91ad4a8} executeQuery: Code: 57. DB::Exception: Table test_5.t_nested_with_dots already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02191_nested_with_dots.sql) (in query: /* ddl_entry=query-0000000069 */ CREATE TABLE test_5.t_nested_with_dots UUID '110bd8af-67d0-4731-acfb-1c834501095e' (`n` Nested(id UInt64, `values.id` Array(UInt64))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 60383, min_bytes_for_wide_part = 9522878, ratio_of_defaults_for_sparse_serialization = 0.9245696663856506, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 488096240, compact_parts_max_bytes_to_buffer = 443551297, compact_parts_max_granules_to_buffer = 167, compact_parts_merge_max_bytes_to_prefetch_part = 20678381, merge_max_block_size = 559, old_parts_lifetime = 271., 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 = 1861416, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63803, primary_key_compress_block_size = 89164), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:34.608568 [ 5326 ] {84ef1d5f-e2f3-41ce-bfa5-dac5e91ad4a8} executeQuery: Code: 57. DB::Exception: Table test_5.t_nested_with_dots already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53612) (comment: 02191_nested_with_dots.sql) (in query: CREATE TABLE t_nested_with_dots (`n` Nested(id UInt64, `values.id` Array(UInt64))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 60383, min_bytes_for_wide_part = 9522878, ratio_of_defaults_for_sparse_serialization = 0.9245696663856506, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 488096240, compact_parts_max_bytes_to_buffer = 443551297, compact_parts_max_granules_to_buffer = 167, compact_parts_merge_max_bytes_to_prefetch_part = 20678381, merge_max_block_size = 559, old_parts_lifetime = 271., 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 = 1861416, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63803, primary_key_compress_block_size = 89164), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:34.629800 [ 5326 ] {84ef1d5f-e2f3-41ce-bfa5-dac5e91ad4a8} TCPHandler: Code: 57. DB::Exception: Table test_5.t_nested_with_dots 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:34.718643 [ 5600 ] {e65e55cd-df61-40c2-9a6d-b8f244bd31ea} 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.10508.altinitytest (altinity build)) (from [::1]:53672) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7349 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e45c7 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) @ 0x00000000116ded14 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) @ 0x00000000116de1bd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f05b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:11:34.739276 [ 5600 ] {e65e55cd-df61-40c2-9a6d-b8f244bd31ea} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7349 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e45c7 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) @ 0x00000000116ded14 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) @ 0x00000000116de1bd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f05b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:11:34.781539 [ 2964 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:35.143086 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:35.725169 [ 5326 ] {f1bf03c3-1e07-4061-a6bb-347333a53df9} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53682) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010ce63aa 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce62fe 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&&) @ 0x00000000116ece18 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8613 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eab36 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f068 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:11:35.741071 [ 5326 ] {f1bf03c3-1e07-4061-a6bb-347333a53df9} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010ce63aa 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce62fe 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&&) @ 0x00000000116ece18 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8613 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eab36 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f068 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:11:35.797577 [ 3470 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:36.147461 [ 3343 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:36.799791 [ 3093 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.153207 [ 3134 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.250820 [ 3596 ] {} 5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.254142 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_2}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.575840 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_74_79_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.707740 [ 3588 ] {} 5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.744281 [ 3588 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_2}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:37.851461 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:38.156877 [ 3286 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:38.731704 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_74_79_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:38.857256 [ 3398 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:39.217101 [ 3162 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:39.863794 [ 3072 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.011613 [ 3596 ] {} 5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.056113 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_0_0_0_3}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.216599 [ 2926 ] {95a33f74-4589-46a7-bb0c-332f2e170e30} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '_column0' in scope SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10. Maybe you meant: ['column0']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37786) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.218668 [ 3453 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.223369 [ 2926 ] {95a33f74-4589-46a7-bb0c-332f2e170e30} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '_column0' in scope SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10. Maybe you meant: ['column0']. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.302818 [ 5326 ] {1ae3400d-36ed-4374-b79c-82ce425068b5} DatabaseReplicated (test_5): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.09.25 21:11:40.330280 [ 5326 ] {1ae3400d-36ed-4374-b79c-82ce425068b5} 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.10508.altinitytest (altinity build)) (from [::1]:37796) (comment: 02486_truncate_and_unexpected_parts.sql) (in query: CREATE TABLE rmt (`n` int) ENGINE = ReplicatedMergeTree('/test/02468/{database}', '1') PARTITION BY n % 2 ORDER BY tuple() SETTINGS replicated_max_ratio_of_wrong_parts = 0, max_suspicious_broken_parts = 0, max_suspicious_broken_parts_bytes = 0, index_granularity = 10044, min_bytes_for_wide_part = 890623807, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 300743447, compact_parts_max_granules_to_buffer = 60, compact_parts_merge_max_bytes_to_prefetch_part = 8523811, merge_max_block_size = 8866, old_parts_lifetime = 90., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 29, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 204525, concurrent_part_removal_threshold = 60, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 11317, primary_key_compress_block_size = 64100), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.347244 [ 5326 ] {1ae3400d-36ed-4374-b79c-82ce425068b5} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.368313 [ 7934 ] {0b8825e5-1048-42ce-90d7-1de01dc364b8} executeQuery: Code: 48. DB::Exception: Alter of type 'MODIFY_ORDER_BY' is not supported by storage Distributed. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37792) (comment: 00910_crash_when_distributed_modify_order_by.sql) (in query: ALTER TABLE union2 MODIFY ORDER BY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000106248eb 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001223b319 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.372070 [ 7934 ] {0b8825e5-1048-42ce-90d7-1de01dc364b8} TCPHandler: Code: 48. DB::Exception: Alter of type 'MODIFY_ORDER_BY' is not supported by storage Distributed. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000106248eb 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001223b319 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:11:40.605087 [ 3592 ] {} eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column s): (while reading from part /var/lib/clickhouse/store/eb6/eb619acf-ab38-4796-bb83-92a619d7f716/20000101_20000101_1_1_0_2/ in table test_ygtw14d2.mutations_r1 (eb619acf-ab38-4796-bb83-92a619d7f716) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.614747 [ 3592 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column s): (while reading from part /var/lib/clickhouse/store/eb6/eb619acf-ab38-4796-bb83-92a619d7f716/20000101_20000101_1_1_0_2/ in table test_ygtw14d2.mutations_r1 (eb619acf-ab38-4796-bb83-92a619d7f716) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:40.871843 [ 3080 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:41.224122 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:41.873660 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:42.226383 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:42.899037 [ 3412 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:43.233569 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:43.901437 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:44.239556 [ 3339 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:44.909574 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:45.071583 [ 7902 ] {f9ed1385-424d-4240-ad89-b91bc3654b3f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49638) (comment: 01395_limit_more_cases.sh) (in query: SELECT 3, 6, count() AS c, min(number) AS first, max(number) AS last, throwIf(first != (3 < 13 AND 6 > 0 ? 3 : 0)), throwIf(last != (3 < 13 AND 6 > 0 ? least(13 - 1, 3 + 6 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(13) LIMIT 3, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:45.089705 [ 7902 ] {f9ed1385-424d-4240-ad89-b91bc3654b3f} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:45.244589 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:45.915413 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:46.249434 [ 3107 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:46.917595 [ 3429 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:47.255488 [ 3406 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:47.926434 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:48.264464 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:48.932867 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:49.268568 [ 3257 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:49.935684 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.275452 [ 3294 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.704416 [ 3754 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Operation timeout (deadline of 10000 ms already expired) for path: /test/02995/test_13/rmt/replicas/1/host. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&, String&&) @ 0x000000000c9687ab 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x00000000134b518e 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x00000000134ae071 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000134b3f87 7. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 9. ? @ 0x00007fd96814bac3 10. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.718518 [ 3300 ] {} test_13.forget_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:11:50.719530 [ 3267 ] {} test_ygtw14d2.mutations_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:11:50.721167 [ 3594 ] {5890d27e-a808-41b7-a813-0f722dcb8b37::20000201_20000201_0_0_0_2} auto DB::ReplicatedMergeMutateTaskBase::executeImpl()::(anonymous class)::operator()() const: Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/replicas/r2/queue/queue-0000000008. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:556: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x00000000134612ac 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:592: DB::ReplicatedMergeTreeQueue::removeProcessedEntry(std::shared_ptr, std::shared_ptr&) @ 0x00000000129fabb4 7. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:149: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_0::operator()() const @ 0x00000000129c970c 8. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c89ae 9. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7796 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 12. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.723455 [ 3142 ] {} test_ygtw14d2.mutations_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:11:50.758535 [ 3091 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.758578 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.758797 [ 3224 ] {} test_ygtw14d2.mutations_r2 (5890d27e-a808-41b7-a813-0f722dcb8b37): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.763211 [ 3045 ] {} test_ygtw14d2.mutations_r1 (eb619acf-ab38-4796-bb83-92a619d7f716): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.783278 [ 8202 ] {a4e1101f-01d0-4dfc-91b3-1e0ab0385615} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_5/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37802) (comment: 03247_object_column_copy.sql) (in query: CREATE TABLE t0 (c0 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x00000000134626ae 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e08a97 9. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:11:50.794985 [ 3155 ] {} test_ygtw14d2.mutations_r2 (5890d27e-a808-41b7-a813-0f722dcb8b37): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/pinned_part_uuids. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x00000000134626ae 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000012a175cd 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000012a10929 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000123b5bb3 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.795667 [ 8202 ] {a4e1101f-01d0-4dfc-91b3-1e0ab0385615} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_5/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x00000000134626ae 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e08a97 9. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:11:50.800531 [ 3487 ] {} test_ygtw14d2.mutations_r2 (5890d27e-a808-41b7-a813-0f722dcb8b37): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 999. Coordination::Exception: Coordination error: Operation timeout. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/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/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error) @ 0x0000000013456ee5 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000001346390f 6. /build/contrib/llvm-project/libcxx/include/vector:1250: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x0000000011906907 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011906660 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::BaseMergePredicate::getCommittingBlocks(std::shared_ptr&, String const&, std::shared_ptr) @ 0x0000000012a1c64a 9. /build/contrib/llvm-project/libcxx/include/new:246: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000012a17333 10. /build/contrib/llvm-project/libcxx/include/optional:260: DB::ReplicatedMergeTreeQueue::tryFinalizeMutations(std::shared_ptr) @ 0x0000000012a13988 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:3968: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68f7 12. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.813205 [ 3283 ] {} test_ygtw14d2.mutations_r1 (eb619acf-ab38-4796-bb83-92a619d7f716): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/mutations. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eb11 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000129fbbad 9. /build/contrib/llvm-project/libcxx/include/tuple:1228: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000012a17580 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000012a10929 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000123b5bb3 12. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.816144 [ 3592 ] {} eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eb11 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001345e66f 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001345e4e9 8. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000134bf884 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001236db6c 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:1912: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x0000000012371737 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000123732af 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001295dac9 13. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c8983 14. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7796 15. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.819677 [ 3592 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3}: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eb11 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001345e66f 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001345e4e9 8. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:139: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000134bf884 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::checkPartChecksumsAndAddCommitOps(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>>&, String, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001236db6c 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:1912: DB::StorageReplicatedMergeTree::getOpsToCheckPartChecksumsAndCommit(std::shared_ptr const&, std::shared_ptr const&, std::optional, bool, std::vector, std::allocator>>&, unsigned long&) @ 0x0000000012371737 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000123732af 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001295dac9 13. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:225: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c8983 14. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7796 15. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.838862 [ 3301 ] {} test_ygtw14d2.mutations_r1 (eb619acf-ab38-4796-bb83-92a619d7f716): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.849314 [ 3293 ] {} test_ygtw14d2.mutations_r2 (5890d27e-a808-41b7-a813-0f722dcb8b37): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.854690 [ 3430 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.860168 [ 3132 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.868796 [ 3408 ] {} test_13.forget_partition (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02995/test_13/rmt/replicas/1/host. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:704: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x00000000134626ae 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000129d0840 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000129cf79c 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000129ce89a 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:50.972770 [ 5600 ] {024e59d8-d1df-443d-8b4f-9b17daad5cde} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/mutations/0000000002. (KEEPER_EXCEPTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37790) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 DELETE WHERE s = 'd' SETTINGS mutations_sync = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001346193a 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345f408 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:610: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000001235987a 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000123e04da 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001240068a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:11:50.979047 [ 5600 ] {024e59d8-d1df-443d-8b4f-9b17daad5cde} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00652_replicated_mutations_zookeeper_test_ygtw14d2/mutations/mutations/0000000002. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001346193a 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345f408 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:610: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000001235987a 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000123e04da 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001240068a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:11:51.022111 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.282818 [ 3069 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.535664 [ 3597 ] {} eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.536769 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_3}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.762792 [ 2964 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.765701 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.816905 [ 3590 ] {} 5890d27e-a808-41b7-a813-0f722dcb8b37::20000201_20000201_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:51.818422 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5890d27e-a808-41b7-a813-0f722dcb8b37::20000201_20000201_0_0_0_3}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.048186 [ 3156 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.287981 [ 3316 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.421117 [ 3601 ] {} 5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_1_1_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.424912 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5890d27e-a808-41b7-a813-0f722dcb8b37::20000101_20000101_1_1_0_4}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.527405 [ 3594 ] {} eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.529134 [ 3594 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_4}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.767828 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:52.772604 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.050545 [ 3343 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.289874 [ 3120 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.596174 [ 3589 ] {} eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.598941 [ 3589 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eb619acf-ab38-4796-bb83-92a619d7f716::20000101_20000101_1_1_0_4}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.770325 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:53.775668 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:54.058550 [ 3180 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:54.305220 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:54.773680 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:54.782429 [ 3368 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:55.060928 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:55.307308 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:55.776050 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:55.784262 [ 3436 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.073603 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.309319 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.405853 [ 7934 ] {1b7febdb-fec2-4dae-b7c3-997ee2e0c1b2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53038) (comment: 01719_join_timezone.sql) (in query: DROP DATABASE IF EXISTS test_sw609v6n ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:11:56.411496 [ 7934 ] {1b7febdb-fec2-4dae-b7c3-997ee2e0c1b2} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.548211 [ 2926 ] {5c56b741-dfd0-4d2f-8d0a-f6004c706097} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53040) (comment: 01719_join_timezone.sql) (in query: DROP DATABASE IF EXISTS test_sw609v6n ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:11:56.552499 [ 2926 ] {5c56b741-dfd0-4d2f-8d0a-f6004c706097} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.780728 [ 2997 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:56.787835 [ 3188 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:57.084482 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:57.087552 [ 7932 ] {1b462a78-50d2-4568-8524-d19113f3032a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57752) (comment: 03209_parameterized_view_with_non_literal_params.sql) (in query: select id from date32_pv(dtparam=(select dt from date32_table_pv where id = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:57.089773 [ 7932 ] {1b462a78-50d2-4568-8524-d19113f3032a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:11:57.311956 [ 3380 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:57.788186 [ 3445 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:57.790058 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:58.070516 [ 7934 ] {bec38707-b590-4485-878c-7fb52c7c2f90} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46408) (comment: 02916_set_formatting.sql) (in query: DROP VIEW 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:11:58.073318 [ 7934 ] {bec38707-b590-4485-878c-7fb52c7c2f90} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:11:58.086519 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:58.258686 [ 7932 ] {2aa8791d-9513-4b90-922d-02638e4848a5} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46420) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(18446744073709551615, 0.9998999834060669);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:11:58.309297 [ 7932 ] {2aa8791d-9513-4b90-922d-02638e4848a5} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:11:58.323900 [ 3235 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:58.425995 [ 7932 ] {ba605a6a-25ff-400f-ac68-cd394f56dd2b} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46420) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:11:58.431900 [ 7932 ] {ba605a6a-25ff-400f-ac68-cd394f56dd2b} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:11:58.792330 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:58.796649 [ 3187 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:59.089386 [ 3333 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:59.326561 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:59.799148 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:59.799522 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:11:59.973433 [ 7932 ] {f0c30d8e-9d61-401e-800f-b347684bf741} executeQuery: Code: 59. DB::Exception: Illegal type Int128 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.10508.altinitytest (altinity build)) (from [::1]:46432) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_int128 PREWHERE 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:11:59.977466 [ 7932 ] {f0c30d8e-9d61-401e-800f-b347684bf741} TCPHandler: Code: 59. DB::Exception: Illegal type Int128 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:00.092046 [ 3023 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:00.328902 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:00.627522 [ 7932 ] {4e52890c-09aa-41e0-914f-7f9f6c066169} executeQuery: Code: 59. DB::Exception: Illegal type Int256 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.10508.altinitytest (altinity build)) (from [::1]:46432) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_int256 PREWHERE 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:00.630223 [ 7932 ] {4e52890c-09aa-41e0-914f-7f9f6c066169} TCPHandler: Code: 59. DB::Exception: Illegal type Int256 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:00.801538 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:00.807564 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:01.094774 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:01.331000 [ 3396 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:01.541322 [ 7932 ] {60c55282-7b4f-4f6b-93b6-000bcb86ba41} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 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.10508.altinitytest (altinity build)) (from [::1]:46432) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_uint128 PREWHERE 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:01.542535 [ 7932 ] {60c55282-7b4f-4f6b-93b6-000bcb86ba41} TCPHandler: Code: 59. DB::Exception: Illegal type UInt128 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:01.804109 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:01.851076 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:02.102502 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:02.320347 [ 7932 ] {5925d076-fc22-4a83-afc0-b74f93e2f4b6} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 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.10508.altinitytest (altinity build)) (from [::1]:46432) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_uint256 PREWHERE 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:02.321702 [ 7932 ] {5925d076-fc22-4a83-afc0-b74f93e2f4b6} TCPHandler: Code: 59. DB::Exception: Illegal type UInt256 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001218e793 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee61f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128ec76c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea423 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:02.335030 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:02.512961 [ 7934 ] {ecb7aaa7-4d0a-4143-9d19-5cc56b3615c4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37870) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:02.515519 [ 7934 ] {ecb7aaa7-4d0a-4143-9d19-5cc56b3615c4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:02.806798 [ 3368 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:02.854455 [ 3436 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:03.110213 [ 3386 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:03.337023 [ 3305 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:03.818299 [ 3033 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:03.867896 [ 3390 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:04.115438 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:04.275503 [ 5326 ] {29cd7110-4c6a-49de-87d6-ecd637e47654} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37820) (comment: 01395_limit_more_cases.sh) (in query: WITH count() AS c, min(number) AS first, max(number) AS last SELECT throwIf(first != (88 < 3 AND 21 > 0 ? 88 : 0)), throwIf(last != (88 < 3 AND 21 > 0 ? least(3 - 1, 88 + 21 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(3) LIMIT 88, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:04.291399 [ 5326 ] {29cd7110-4c6a-49de-87d6-ecd637e47654} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:04.341419 [ 3327 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:04.831642 [ 3422 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:04.871727 [ 3243 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:05.117130 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:05.350860 [ 3259 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:05.386810 [ 2929 ] {7fb1d90b-9b28-43d1-ba46-0cd35dc3b0d4} 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.10508.altinitytest (altinity build)) (from [::1]:46506) (comment: 00739_array_element_nullable_string_mattrobenolt.sql) (in query: select count(), a[1] from wups group by a[1] order by a[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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:05.390511 [ 2929 ] {7fb1d90b-9b28-43d1-ba46-0cd35dc3b0d4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:05.879517 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:05.916762 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:06.123331 [ 3435 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:06.356724 [ 3323 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:06.881627 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:06.918634 [ 3429 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:07.125311 [ 3180 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:07.359313 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:07.888675 [ 3424 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:07.923721 [ 3465 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:08.130553 [ 3066 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:08.368929 [ 3200 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:08.891669 [ 3456 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:08.930642 [ 3063 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:09.132826 [ 3054 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:09.377819 [ 3309 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:09.547449 [ 7932 ] {5339997f-a588-4991-be0a-4203ad9390d2} DatabaseReplicated (test_5): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.09.25 21:12:09.628735 [ 7932 ] {5339997f-a588-4991-be0a-4203ad9390d2} 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.10508.altinitytest (altinity build)) (from [::1]:40780) (comment: 03143_parallel_replicas_mat_view_bug.sql) (in query: CREATE MATERIALIZED VIEW mv_table (str String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/03143_parallel_replicas_mat_view_bug', '{replica}') ORDER BY str AS SELECT str AS str FROM null_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de87f5 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:12:09.649334 [ 7932 ] {5339997f-a588-4991-be0a-4203ad9390d2} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de87f5 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:12:09.893998 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:09.937900 [ 3319 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:10.150410 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:10.385179 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:10.794265 [ 7932 ] {61ac9fb1-d5a8-42d2-af77-b0de6926ce38} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: /* ddl_entry=query-0000000085 */ CREATE TABLE test_5.mytable_local UUID 'c272b401-d5ad-4889-94d5-88480bb382ef' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:10.831531 [ 7932 ] {61ac9fb1-d5a8-42d2-af77-b0de6926ce38} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40784) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:10.835666 [ 7932 ] {61ac9fb1-d5a8-42d2-af77-b0de6926ce38} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:10.912687 [ 3130 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:10.943888 [ 3262 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:11.154061 [ 3083 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:11.182088 [ 7932 ] {7a086c01-922e-4362-a26e-d0ba50b4dd16} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: /* ddl_entry=query-0000000086 */ CREATE TABLE test_5.mytable_local UUID '0775096a-0bcb-4504-acfa-8371a96427f4' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f89 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.204907 [ 7932 ] {7a086c01-922e-4362-a26e-d0ba50b4dd16} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40784) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f89 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.211568 [ 7932 ] {7a086c01-922e-4362-a26e-d0ba50b4dd16} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f89 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.388991 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:11.635501 [ 7932 ] {5b2b3fa1-c15d-478b-82eb-1560ba420bff} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: /* ddl_entry=query-0000000087 */ CREATE TABLE test_5.mytable_local UUID '95a431c0-7d4c-4087-b22a-4fbd9958ccfb' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012925006 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.673935 [ 7932 ] {5b2b3fa1-c15d-478b-82eb-1560ba420bff} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40784) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 32475, min_bytes_for_wide_part = 215570150, ratio_of_defaults_for_sparse_serialization = 0.0010228679748252034, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 504906058, compact_parts_max_bytes_to_buffer = 61959845, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 26764811, merge_max_block_size = 20217, old_parts_lifetime = 451., prefer_fetch_merged_part_size_threshold = 6527062954, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7516184768, index_granularity_bytes = 28796313, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31105, primary_key_compress_block_size = 22338), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012925006 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.676672 [ 7932 ] {5b2b3fa1-c15d-478b-82eb-1560ba420bff} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012925006 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000012777540 6. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 7. /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>&&) @ 0x0000000012a754d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 9. /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 @ 0x00000000122534a7 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 16. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 18. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:11.915090 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:11.951461 [ 3273 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:12.155822 [ 3287 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:12.400584 [ 3440 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:12.668717 [ 7932 ] {c3743aee-a1f1-4ef8-a42d-47c63d367043} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: /* ddl_entry=query-0000000089 */ ALTER TABLE test_5.mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x00000000127abef3 6. /build/src/Storages/StorageMergeTree.cpp:350: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000012a78be4 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecf9 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dcae 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:12:12.701395 [ 7932 ] {c3743aee-a1f1-4ef8-a42d-47c63d367043} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40784) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: ALTER TABLE mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x00000000127abef3 6. /build/src/Storages/StorageMergeTree.cpp:350: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000012a78be4 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecf9 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dcae 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:12:12.708479 [ 7932 ] {c3743aee-a1f1-4ef8-a42d-47c63d367043} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x00000000129427cb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000012924f0c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x00000000127abef3 6. /build/src/Storages/StorageMergeTree.cpp:350: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000012a78be4 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecf9 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dcae 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:12:12.928075 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:12.958114 [ 3218 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:13.158562 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:13.410775 [ 3409 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:13.940555 [ 3047 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:13.961353 [ 3138 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:14.162837 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:14.419167 [ 3302 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:14.452549 [ 7932 ] {47bf9ff7-6e6d-42b9-8455-dc4d2fec03d8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02902_select_subcolumns_from_engine_null.sql) (in query: /* ddl_entry=query-0000000091 */ TRUNCATE TABLE test_5.null_02902), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 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>&) @ 0x0000000011572b41 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:12:14.493298 [ 7932 ] {47bf9ff7-6e6d-42b9-8455-dc4d2fec03d8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40786) (comment: 02902_select_subcolumns_from_engine_null.sql) (in query: DROP TABLE null_02902;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 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>&) @ 0x0000000011572b41 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:12:14.500289 [ 7932 ] {47bf9ff7-6e6d-42b9-8455-dc4d2fec03d8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 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>&) @ 0x0000000011572b41 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:12:14.942380 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:14.965747 [ 3144 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:15.166573 [ 3170 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:15.251057 [ 7932 ] {a9ce82e0-7fa1-41f4-8dda-f765d00762bd} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrZero(1.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007360b14 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:15.252848 [ 7932 ] {a9ce82e0-7fa1-41f4-8dda-f765d00762bd} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero(1.1, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007360b14 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:15.420980 [ 3191 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:15.943896 [ 2997 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:15.967556 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:16.168258 [ 2979 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:16.303240 [ 7932 ] {fa5297ea-d746-452e-bc6e-384d25694f5b} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000073609eb 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.305291 [ 7932 ] {fa5297ea-d746-452e-bc6e-384d25694f5b} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrZero must be constant: In scope SELECT toDecimal32OrZero('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000073609eb 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.424904 [ 3318 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:16.434392 [ 7932 ] {5ecedbd7-31ac-4ed2-8d0d-cf3068ad9cb0} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal64OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007361e0b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.436989 [ 7932 ] {5ecedbd7-31ac-4ed2-8d0d-cf3068ad9cb0} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrZero must be constant: In scope SELECT toDecimal64OrZero('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007361e0b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.540228 [ 7932 ] {843e5ff9-f93c-4b61-9092-4cc30ddfc014} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal128OrZero('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000736326b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.543633 [ 7932 ] {843e5ff9-f93c-4b61-9092-4cc30ddfc014} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrZero must be constant: In scope SELECT toDecimal128OrZero('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrZero, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)1, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000736326b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:16.945677 [ 3188 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:16.970295 [ 3345 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:17.098482 [ 7932 ] {6fe767ad-c858-447b-9e78-b6be01bc1b4b} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrNull(1.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007381f6b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:17.100537 [ 7932 ] {6fe767ad-c858-447b-9e78-b6be01bc1b4b} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull(1.1, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007381f6b 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:17.170060 [ 3351 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:17.434593 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:17.947513 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:17.975402 [ 3245 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.178575 [ 3317 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.268873 [ 3598 ] {} fc2df51b-efdf-4907-8425-bb46bacbab83::all_0_0_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.274207 [ 3598 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fc2df51b-efdf-4907-8425-bb46bacbab83::all_0_0_0_4}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.291800 [ 7932 ] {0734780f-f2df-4baf-8491-3f0aae729c33} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal32OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007381e41 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.296208 [ 7932 ] {0734780f-f2df-4baf-8491-3f0aae729c33} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal32OrNull must be constant: In scope SELECT toDecimal32OrNull('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal32OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007381e41 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.439287 [ 3371 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.506263 [ 7932 ] {ab089eae-6405-429b-898c-ae8b9d09169d} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal64OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000073835a1 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.511184 [ 7932 ] {ab089eae-6405-429b-898c-ae8b9d09169d} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal64OrNull must be constant: In scope SELECT toDecimal64OrNull('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>, DB::(anonymous namespace)::NameToDecimal64OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000073835a1 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.619360 [ 7932 ] {383c0e0c-a0d5-4d6a-96e6-58c11bab10fb} executeQuery: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40790) (comment: 00700_to_decimal_or_something.sql) (in query: SELECT toDecimal128OrNull('1', rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007384d41 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.630830 [ 7932 ] {383c0e0c-a0d5-4d6a-96e6-58c11bab10fb} TCPHandler: Code: 44. DB::Exception: Second argument for function toDecimal128OrNull must be constant: In scope SELECT toDecimal128OrNull('1', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvertFromString>>, DB::(anonymous namespace)::NameToDecimal128OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007384d41 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:12:18.950857 [ 3262 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:18.981778 [ 2996 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.035480 [ 3598 ] {} fc2df51b-efdf-4907-8425-bb46bacbab83::all_0_0_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.037151 [ 3598 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fc2df51b-efdf-4907-8425-bb46bacbab83::all_0_0_0_4}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.183852 [ 3263 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.444183 [ 3042 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.955785 [ 3114 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:19.984014 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:20.188677 [ 3204 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:20.446202 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:20.961758 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:20.999500 [ 3433 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:21.200921 [ 3276 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:21.448756 [ 3183 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:21.564061 [ 7898 ] {ca830da2-4720-4449-b234-712b458a3a57} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54426) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:21.575392 [ 7898 ] {ca830da2-4720-4449-b234-712b458a3a57} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:21.964150 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:22.005385 [ 3321 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:22.202872 [ 3066 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:22.252967 [ 7932 ] {4e9fa80c-65e6-4f0b-b129-215e03fe13ef} executeQuery: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54454) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000') FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createRuntime(int, String const&) @ 0x000000000b762c8c 3. /build/src/Functions/throwIf.cpp:137: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b76114f 4. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 5. /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 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::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197afd 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 11. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 17. /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*) @ 0x0000000012d6ddea 18. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:12:22.266718 [ 7932 ] {4e9fa80c-65e6-4f0b-b129-215e03fe13ef} TCPHandler: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createRuntime(int, String const&) @ 0x000000000b762c8c 3. /build/src/Functions/throwIf.cpp:137: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b76114f 4. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 5. /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 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::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197afd 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 11. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 13. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 17. /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*) @ 0x0000000012d6ddea 18. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:12:22.452601 [ 3291 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:22.801944 [ 7898 ] {cfac0fe7-3fe5-414e-8d82-c82d0a7d5bf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54460) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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 const&, char const*&&) @ 0x000000000b762d6b 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b761a05 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:22.810167 [ 7898 ] {cfac0fe7-3fe5-414e-8d82-c82d0a7d5bf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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 const&, char const*&&) @ 0x000000000b762d6b 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b761a05 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:22.966216 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:23.007473 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:23.204814 [ 3211 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:23.368373 [ 7615 ] {321e51f9-a871-44cb-8036-7a48945d7e50} executeQuery: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54486) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b761c76 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:23.379592 [ 7615 ] {321e51f9-a871-44cb-8036-7a48945d7e50} TCPHandler: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b761c76 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:23.456960 [ 3249 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:23.973381 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.009968 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.051460 [ 7932 ] {308b7981-7cdb-4790-9632-2ac1c0a7e492} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60900) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_ygtw14d2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.054831 [ 7932 ] {308b7981-7cdb-4790-9632-2ac1c0a7e492} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.088313 [ 7615 ] {3283783b-17ee-4934-b720-e6a20eb0c6ca} executeQuery: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54502) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(42)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.092786 [ 7615 ] {3283783b-17ee-4934-b720-e6a20eb0c6ca} TCPHandler: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.151246 [ 8473 ] {3880f223-aa71-4891-a0a1-2ac5b2dcf8eb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60912) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_ygtw14d2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.164800 [ 8473 ] {3880f223-aa71-4891-a0a1-2ac5b2dcf8eb} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.207035 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.248272 [ 7932 ] {7d7f5b37-58d6-4e06-bb79-a26dc7fd36d4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60928) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_ygtw14d2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.253189 [ 7932 ] {7d7f5b37-58d6-4e06-bb79-a26dc7fd36d4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.382077 [ 7615 ] {08a72f79-461a-48b9-93c6-6b9f6a9e2036} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60936) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_ygtw14d2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.393810 [ 7615 ] {08a72f79-461a-48b9-93c6-6b9f6a9e2036} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.458733 [ 3050 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:24.749464 [ 8473 ] {b6626633-3811-4ac4-a055-701939943920} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54512) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(0)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.761303 [ 8473 ] {b6626633-3811-4ac4-a055-701939943920} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:24.975842 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:25.051413 [ 3232 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:25.212319 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:25.465995 [ 3388 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:25.548456 [ 8473 ] {d873c9d2-0535-41c3-93f8-4a9e209cce6b} executeQuery: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54522) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(101)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:25.555697 [ 8473 ] {d873c9d2-0535-41c3-93f8-4a9e209cce6b} TCPHandler: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:25.984171 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:26.081943 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:26.217153 [ 2965 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:26.258359 [ 3595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {06e0dcf3-6e7a-4ddb-850b-40d5fef4d059::202509_1_71_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:26.327029 [ 7932 ] {c400abd5-ca1b-4997-b494-d61b3862cf19} executeQuery: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54528) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(102)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:26.346205 [ 7932 ] {c400abd5-ca1b-4997-b494-d61b3862cf19} TCPHandler: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:26.468090 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:26.947663 [ 8473 ] {87ede7b7-d2b0-4245-8ca8-13b92451e2ba} executeQuery: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50352) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1001)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:26.952781 [ 8473 ] {87ede7b7-d2b0-4245-8ca8-13b92451e2ba} TCPHandler: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:26.990830 [ 3483 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:27.084188 [ 3159 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:27.294000 [ 3295 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:27.470148 [ 3272 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:27.521135 [ 7932 ] {b00a9d2c-45f6-4a9d-9594-e4455ea2088c} 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.10508.altinitytest (altinity build)) (from [::1]:54534) (comment: 02364_dictionary_datetime_64_attribute_crash.sql) (in query: select count(*) from dat where eventTimestamp >= (select eventTimestamp from datDictionary);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:27.525723 [ 7932 ] {b00a9d2c-45f6-4a9d-9594-e4455ea2088c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:27.565403 [ 8473 ] {e6215097-4369-4697-9933-3f13aa9c24a7} executeQuery: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 1'. () (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50360) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1002)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:27.571680 [ 8473 ] {e6215097-4369-4697-9933-3f13aa9c24a7} TCPHandler: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:27.775185 [ 7932 ] {8828b204-02b0-408d-bd52-9c3465c720a6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41862) (comment: 02364_dictionary_datetime_64_attribute_crash.sql) (in query: DROP DATABASE IF EXISTS test_kxic8at4 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:27.781420 [ 7932 ] {8828b204-02b0-408d-bd52-9c3465c720a6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:27.994788 [ 3297 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:28.085745 [ 3160 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:28.201735 [ 8473 ] {58dafe8d-001d-4325-9cc8-e67d1244e5f7} executeQuery: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. () (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50372) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(999999)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:28.235087 [ 8473 ] {58dafe8d-001d-4325-9cc8-e67d1244e5f7} TCPHandler: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:28.296157 [ 3211 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:28.454935 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:12:28.474928 [ 3419 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:28.718704 [ 7897 ] {307adbcb-0e87-4d15-b450-821bac2a0521} executeQuery: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. () (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50392) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(-1)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:28.735687 [ 7897 ] {307adbcb-0e87-4d15-b450-821bac2a0521} TCPHandler: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:12:28.996743 [ 3274 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:29.101613 [ 3427 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:29.297962 [ 3054 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:29.479463 [ 3022 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:29.998423 [ 3184 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:30.113599 [ 3481 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:30.302734 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:30.485528 [ 3292 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:31.000594 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:31.119432 [ 3136 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:31.304848 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:31.489544 [ 3236 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:32.004831 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:32.125271 [ 3350 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:32.312526 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:32.495414 [ 3202 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:33.007983 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:33.127882 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:33.322194 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:33.499806 [ 3420 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:33.545682 [ 2929 ] {c7bbe48b-2660-4604-aa0b-54606e598cf5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=4): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40770) (comment: 02252_jit_profile_events.sql) (in query: SELECT ProfileEvents['CompileFunction'] FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query == 'SELECT avg(number), avg(number + 1), avg(number + 2) FROM numbers(1) GROUP BY number;' AND event_date >= yesterday() AND event_time > now() - interval 10 minute 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d2385e 14. /build/src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d703e8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddc51 16. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d22bbc 17. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 19. /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) @ 0x00000000128f5f4c 20. /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&) @ 0x000000001282d934 21. /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 @ 0x000000001282a6ee 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 24. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 2025.09.25 21:12:33.555863 [ 2929 ] {c7bbe48b-2660-4604-aa0b-54606e598cf5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=4): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d189e8 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d2385e 14. /build/src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d703e8 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddc51 16. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d22bbc 17. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 19. /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) @ 0x00000000128f5f4c 20. /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&) @ 0x000000001282d934 21. /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 @ 0x000000001282a6ee 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 24. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 2025.09.25 21:12:33.604256 [ 8473 ] {218414e0-022b-429b-9367-ae38bbefe2c3} 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.10508.altinitytest (altinity build)) (from [::1]:50404) (comment: 02845_arrayShiftRotate.sql) (in query: select arrayRotateLeft(a, 2) from t02845;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:33.606309 [ 8473 ] {218414e0-022b-429b-9367-ae38bbefe2c3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:34.013479 [ 3275 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:34.031834 [ 7932 ] {5bd58f3b-2dc2-49ad-9e01-e4cd3661b86a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50472) (comment: 01683_codec_encrypted.sql) (in query: SELECT * FROM encryption_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:34.038323 [ 7932 ] {5bd58f3b-2dc2-49ad-9e01-e4cd3661b86a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:34.129857 [ 3140 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:34.328417 [ 3007 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:34.505997 [ 3152 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:34.917024 [ 7897 ] {2f07e157-5870-4963-8fd2-88a3b73c65eb} 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.10508.altinitytest (altinity build)) (from [::1]:50420) (comment: 00602_throw_if.sh) (in query: SELECT sum(x = 0) FROM (SELECT throwIf(number = 1000) AS x 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:34.921230 [ 7897 ] {2f07e157-5870-4963-8fd2-88a3b73c65eb} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:12:35.017938 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:35.101078 [ 7932 ] {797dbed3-16b9-4319-a3d6-5a81490b7768} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41938) (comment: 00068_empty_tiny_log.sql) (in query: DROP DATABASE IF EXISTS test_kuxhseak ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:35.111346 [ 7932 ] {797dbed3-16b9-4319-a3d6-5a81490b7768} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:35.136105 [ 3298 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:35.333675 [ 3015 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:35.507824 [ 3249 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:36.020839 [ 3156 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:36.158304 [ 3343 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:36.336253 [ 3239 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:36.514372 [ 3219 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:37.030552 [ 3014 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:37.181857 [ 3046 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:37.343719 [ 3238 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:37.518873 [ 3252 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.034778 [ 3108 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.187180 [ 3467 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.345359 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.520453 [ 3181 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.913927 [ 7902 ] {eb83d041-ab1e-4fda-b281-4f2031ad0691} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50310) (comment: 02867_null_lc_in_bug.sql) (in query: DROP DATABASE IF EXISTS test_uy6nq5yz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:38.916691 [ 7902 ] {eb83d041-ab1e-4fda-b281-4f2031ad0691} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:38.970830 [ 5600 ] {f0ddb41b-f18e-4d91-8ebc-1526dbfa6233} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50324) (comment: 02867_null_lc_in_bug.sql) (in query: DROP DATABASE IF EXISTS test_uy6nq5yz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:38.973186 [ 5600 ] {f0ddb41b-f18e-4d91-8ebc-1526dbfa6233} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:39.031421 [ 7902 ] {6d35150d-ccda-4efb-9460-6dcb97c64d3c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50336) (comment: 02867_null_lc_in_bug.sql) (in query: DROP DATABASE IF EXISTS test_uy6nq5yz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:39.033750 [ 7902 ] {6d35150d-ccda-4efb-9460-6dcb97c64d3c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:39.040983 [ 3078 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:39.195603 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:39.351495 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:39.522869 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:40.045789 [ 3105 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:40.198301 [ 3191 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:40.374619 [ 3244 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:40.535203 [ 3146 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:41.047578 [ 3329 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:41.200938 [ 3410 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:41.383636 [ 3049 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:41.537149 [ 3358 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:42.055020 [ 3325 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:42.124278 [ 7932 ] {f78deae5-e473-4284-ae6c-d30b48e5b81c} executeQuery: Code: 264. DB::Exception: Table test_5.left_join (653b2242-cc48-41c2-9abc-fe73f6432813) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51812) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 LEFT JOIN left_join j USING(x) ORDER BY x, str, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000012293c05 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&) @ 0x0000000011684cc7 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:12:42.128919 [ 7932 ] {f78deae5-e473-4284-ae6c-d30b48e5b81c} TCPHandler: Code: 264. DB::Exception: Table test_5.left_join (653b2242-cc48-41c2-9abc-fe73f6432813) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000012293c05 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&) @ 0x0000000011684cc7 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:12:42.204276 [ 3203 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:42.268211 [ 7932 ] {c3ae87b5-1cf8-4a0c-ba14-448c34ccd850} executeQuery: Code: 264. DB::Exception: Table test_5.full_join (989f7caf-ce7e-4a97-bc16-e0d11c59d4e6) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51812) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 FULL JOIN full_join j USING(x) ORDER BY x, str, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000012293c05 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&) @ 0x0000000011684cc7 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:12:42.272575 [ 7932 ] {c3ae87b5-1cf8-4a0c-ba14-448c34ccd850} TCPHandler: Code: 264. DB::Exception: Table test_5.full_join (989f7caf-ce7e-4a97-bc16-e0d11c59d4e6) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000012293c05 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&) @ 0x0000000011684cc7 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&) @ 0x000000001166dfe6 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&) @ 0x0000000011662ba2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:12:42.388980 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:42.542849 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:43.057308 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:43.206910 [ 3262 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:43.391698 [ 3032 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:43.549762 [ 3268 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:43.943250 [ 2929 ] {10eaed42-e5be-4098-b70e-103dce938848} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51932) (comment: 02125_lz4_compression_bug_CSV.sh) (in query: INSERT INTO file SELECT * FROM numbers(2500000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb16c5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0704 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000012eb2277 10. /build/src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::write(DB::Block const&) @ 0x0000000012d76248 11. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x000000001226d930 12. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 13. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 19. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:12:43.961509 [ 2929 ] {10eaed42-e5be-4098-b70e-103dce938848} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb16c5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0704 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x0000000012eb2277 10. /build/src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::write(DB::Block const&) @ 0x0000000012d76248 11. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x000000001226d930 12. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 13. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 19. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:12:44.067324 [ 3141 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:44.210596 [ 3393 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:44.396782 [ 3334 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:44.555438 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:44.778849 [ 17867 ] {40d58725-1eaa-4629-9b4e-ffd8c06997e9} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb3e9a 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2876 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 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. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:44.865790 [ 7898 ] {40d58725-1eaa-4629-9b4e-ffd8c06997e9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_13/data.CSV.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51938) (comment: 02125_lz4_compression_bug_CSV.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb3e9a 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2876 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 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. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:12:44.880867 [ 7898 ] {40d58725-1eaa-4629-9b4e-ffd8c06997e9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_13/data.CSV.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb3e9a 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2876 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 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. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:12:44.968272 [ 4056 ] {70e31977-abd7-476c-8199-e7399f02a4d5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51926) (comment: 02521_to_custom_day_of_week.sql) (in query: select toDayOfWeek(today(), -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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/IFunctionCustomWeek.h:0: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000b7837a5 5. /build/src/Functions/FunctionCustomWeekToSomething.h:0: DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7815ad 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:44.975704 [ 4056 ] {70e31977-abd7-476c-8199-e7399f02a4d5} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/IFunctionCustomWeek.h:0: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000b7837a5 5. /build/src/Functions/FunctionCustomWeekToSomething.h:0: DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7815ad 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:12:44.997208 [ 7932 ] {be6a0f96-f06a-4b20-bb3b-621c88a9f56e} executeQuery: Code: 57. DB::Exception: Table test_5.left_join already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01051_all_join_engine.sql) (in query: /* ddl_entry=query-0000000101 */ CREATE TABLE test_5.left_join UUID 'c8b2e396-a366-4b7d-888d-e94c6c928a83' (`x` UInt32, `s` String) ENGINE = Join(`ALL`, LEFT, x) SETTINGS join_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:45.027802 [ 7932 ] {be6a0f96-f06a-4b20-bb3b-621c88a9f56e} executeQuery: Code: 57. DB::Exception: Table test_5.left_join already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51812) (comment: 01051_all_join_engine.sql) (in query: CREATE TABLE left_join (x UInt32, s String) engine = Join(ALL, LEFT, x) SETTINGS join_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:45.030755 [ 7932 ] {be6a0f96-f06a-4b20-bb3b-621c88a9f56e} TCPHandler: Code: 57. DB::Exception: Table test_5.left_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:45.072345 [ 3346 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:45.221360 [ 3443 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:45.399237 [ 3380 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:45.561705 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:46.078503 [ 3010 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:46.224111 [ 3295 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:46.305827 [ 4665 ] {c0590f44-90a1-4bec-b9a5-79eba3ce3426} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02810_fix_remove_dedundant_distinct_view.sql) (in query: /* ddl_entry=query-0000000102 */ CREATE TABLE test_5.tab UUID '2d4b7a9e-8c5d-4171-a620-45b490603242' (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY (x, y) SETTINGS index_granularity = 36482, 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 = 143189429, compact_parts_max_bytes_to_buffer = 177839066, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 20095562, merge_max_block_size = 19755, old_parts_lifetime = 240., prefer_fetch_merged_part_size_threshold = 6778837621, vertical_merge_algorithm_min_rows_to_activate = 426432, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8500192, concurrent_part_removal_threshold = 75, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 90259, primary_key_compress_block_size = 37905), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:46.338436 [ 4665 ] {c0590f44-90a1-4bec-b9a5-79eba3ce3426} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51980) (comment: 02810_fix_remove_dedundant_distinct_view.sql) (in query: CREATE TABLE tab (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY (x, y) SETTINGS index_granularity = 36482, 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 = 143189429, compact_parts_max_bytes_to_buffer = 177839066, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 20095562, merge_max_block_size = 19755, old_parts_lifetime = 240., prefer_fetch_merged_part_size_threshold = 6778837621, vertical_merge_algorithm_min_rows_to_activate = 426432, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8500192, concurrent_part_removal_threshold = 75, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 90259, primary_key_compress_block_size = 37905), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:46.377004 [ 4665 ] {c0590f44-90a1-4bec-b9a5-79eba3ce3426} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:12:46.405158 [ 3432 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:46.564848 [ 3395 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.081460 [ 3427 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.136542 [ 5600 ] {36b89615-782b-4da4-b6d8-c40bab345b73} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43920) (comment: 03081_analyzer_agg_func_CTE.sql) (in query: DROP DATABASE IF EXISTS test_mxfaydoz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.141732 [ 5600 ] {36b89615-782b-4da4-b6d8-c40bab345b73} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.233223 [ 3326 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.407339 [ 3409 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.409504 [ 5600 ] {17cc33c9-d24a-44f3-9c2c-55c47517a64d} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32978) (comment: 01428_h3_range_check.sql) (in query: SELECT h3ToChildren(599405990164561919, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:12:47.410963 [ 4665 ] {4695088c-01d3-4a2f-9e42-266ed6fd832d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.413219 [ 4665 ] {4695088c-01d3-4a2f-9e42-266ed6fd832d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.413506 [ 5600 ] {17cc33c9-d24a-44f3-9c2c-55c47517a64d} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:12:47.487729 [ 4665 ] {368ad5a6-9063-47d1-9ac3-a2ca6d07d94c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT JSON settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.493939 [ 4665 ] {368ad5a6-9063-47d1-9ac3-a2ca6d07d94c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.574378 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:47.594665 [ 4665 ] {b84de61c-ac94-4f37-ba05-38cb07fc36ab} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT TSVWithNamesAndTypes settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.598072 [ 4665 ] {b84de61c-ac94-4f37-ba05-38cb07fc36ab} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.644038 [ 5600 ] {73b712b2-b79b-49a3-8bf0-eca6e98881a4} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32978) (comment: 01428_h3_range_check.sql) (in query: SELECT h3ToParent(599405990164561919, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/h3ToParent.cpp:0: DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000935e1ae 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:12:47.649358 [ 5600 ] {73b712b2-b79b-49a3-8bf0-eca6e98881a4} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/h3ToParent.cpp:0: DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000935e1ae 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:12:47.707439 [ 4665 ] {d6b6313d-ee44-401e-abe3-cbc8b2dfa5e0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT CSVWithNamesAndTypes settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.709851 [ 4665 ] {d6b6313d-ee44-401e-abe3-cbc8b2dfa5e0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.859681 [ 4665 ] {26aca9c5-e23b-46d0-885f-59c9ad64c962} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT JSONCompactEachRowWithNamesAndTypes settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:47.861675 [ 4665 ] {26aca9c5-e23b-46d0-885f-59c9ad64c962} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:48.002673 [ 4665 ] {91b1db1e-f505-4117-ab02-00d88212d658} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT XML settings max_result_rows = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:48.006269 [ 4665 ] {91b1db1e-f505-4117-ab02-00d88212d658} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:48.083956 [ 3481 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:48.179266 [ 4665 ] {9e6b0414-0285-48b9-baae-7560cac5a307} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32970) (comment: 01553_settings_early_apply.sql) (in query: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:48.182416 [ 4665 ] {9e6b0414-0285-48b9-baae-7560cac5a307} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&&) @ 0x0000000010c21e6b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c21c29 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe1b0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 13. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:48.235952 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:48.413314 [ 3019 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:48.576774 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:49.091739 [ 3000 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:49.202727 [ 4665 ] {c2283dbe-73cb-493a-acbd-9704bc33f3fc} DatabaseReplicated (test_5): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.09.25 21:12:49.206754 [ 4665 ] {c2283dbe-73cb-493a-acbd-9704bc33f3fc} 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.10508.altinitytest (altinity build)) (from [::1]:33000) (comment: 02863_delayed_source_with_totals_and_extremes.sql) (in query: CREATE TABLE `02863_delayed_source` (`a` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/02863_delayed_source/{replica}', 'r1') ORDER BY a SETTINGS index_granularity = 23588, min_bytes_for_wide_part = 50280287, ratio_of_defaults_for_sparse_serialization = 0.2013648897409439, replace_long_file_name_to_hash = true, max_file_name_length = 118, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 320642731, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5254491, merge_max_block_size = 15369, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 470732, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10238389635, index_granularity_bytes = 18836058, concurrent_part_removal_threshold = 30, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 32391, primary_key_compress_block_size = 39440), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:12:49.222957 [ 4665 ] {c2283dbe-73cb-493a-acbd-9704bc33f3fc} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010de6edd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8798 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8c7c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:12:49.241991 [ 3065 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:49.415727 [ 3105 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:49.579673 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:50.094886 [ 3386 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:50.244469 [ 3455 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:50.418172 [ 3318 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:50.587705 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:51.185637 [ 3171 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:51.250711 [ 3472 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:51.420413 [ 3489 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:51.593142 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:52.197936 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:52.261950 [ 3161 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:52.422642 [ 3157 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:52.595322 [ 3360 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:53.204126 [ 3186 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:53.267828 [ 3082 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:53.428446 [ 3024 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:53.597737 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:53.789070 [ 4665 ] {74daf0bd-3833-4918-beca-66f4284b1d90} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33086) (in query: show create user u_01939), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:53.801332 [ 4665 ] {74daf0bd-3833-4918-beca-66f4284b1d90} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:12:54.207237 [ 3257 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:54.270387 [ 3069 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:54.434488 [ 3221 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:54.600230 [ 2989 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:55.214160 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:55.277839 [ 3477 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:55.438250 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:55.606395 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:56.221751 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:56.284098 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:56.445707 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:56.608921 [ 3354 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:56.973240 [ 5600 ] {2ae1f5b4-4d35-4ff0-a627-c251a8160c68} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=5): (while reading column n.x): (while reading from part /var/lib/clickhouse/store/052/0522f091-7e06-4890-a5c8-c7fb238f20fc/1_2_12_1/ in table test_5.mt_compact (0522f091-7e06-4890-a5c8-c7fb238f20fc) located on disk default of type local, from mark 0 with max_rows_to_read = 11): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33006) (comment: 01055_compact_parts.sql) (in query: select * from mt_compact order by a, s 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128be7a2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bd88c 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()() @ 0x00000000128bf864 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c171f 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:12:57.002762 [ 5600 ] {2ae1f5b4-4d35-4ff0-a627-c251a8160c68} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=5): (while reading column n.x): (while reading from part /var/lib/clickhouse/store/052/0522f091-7e06-4890-a5c8-c7fb238f20fc/1_2_12_1/ in table test_5.mt_compact (0522f091-7e06-4890-a5c8-c7fb238f20fc) located on disk default of type local, from mark 0 with max_rows_to_read = 11): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba56e5 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128be7a2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bd88c 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()() @ 0x00000000128bf864 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c171f 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:12:57.226736 [ 3305 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:57.291006 [ 3058 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:57.448518 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:57.615410 [ 3459 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:58.230109 [ 3253 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:58.298373 [ 3166 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:58.457201 [ 3258 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:58.619192 [ 3256 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:59.232156 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:59.300074 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:59.459969 [ 3048 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:12:59.621580 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:00.234435 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:00.302316 [ 3490 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:00.462137 [ 3342 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:00.633291 [ 3445 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:01.237109 [ 3246 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:01.308312 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:01.464983 [ 3315 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:01.636121 [ 3081 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:02.239736 [ 3418 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:02.310529 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:02.467628 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:02.638893 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:03.016470 [ 2926 ] {2e297d2d-8c3e-4794-8db9-81b95b556052} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37886) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:13:03.019032 [ 2926 ] {2e297d2d-8c3e-4794-8db9-81b95b556052} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:03.242603 [ 3065 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:03.315209 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:03.481915 [ 3235 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:03.645050 [ 3354 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:04.249341 [ 3206 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:04.317962 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:04.494902 [ 3441 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:04.664137 [ 2995 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:05.007288 [ 4665 ] {31d58e13-2e2d-4a6d-8108-a1c513a9130c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33126) (comment: 03132_jit_sort_description_crash_fix.sql) (in query: SELECT col1 FROM test1_00395 ORDER BY multiIf(27, 1, multiIf(materialize(1), toLowCardinality(2), 3, 1, 4), NULL, 4) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:05.020578 [ 4665 ] {31d58e13-2e2d-4a6d-8108-a1c513a9130c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:05.251774 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:05.320708 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:05.497817 [ 3219 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:05.666979 [ 3023 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:06.256606 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:06.323947 [ 3239 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:06.504245 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:06.715201 [ 3035 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:07.159432 [ 4665 ] {b6e7958d-9b76-4d50-8780-150838949c30} executeQuery: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40678) (comment: 01721_constraints_constant_expressions.sql) (in query: INSERT INTO constraint_constant_number_expression_non_uint8 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f93170 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:13:07.164470 [ 4665 ] {b6e7958d-9b76-4d50-8780-150838949c30} TCPHandler: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f93170 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:13:07.258975 [ 3294 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:07.272357 [ 8473 ] {61e96d4d-113e-430d-9ee9-310741b00a84} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.capnp. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36950) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_5-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000012e36abf 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&) @ 0x0000000012e39785 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:07.300240 [ 8473 ] {61e96d4d-113e-430d-9ee9-310741b00a84} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000012e36abf 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&) @ 0x0000000012e39785 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:07.326505 [ 3131 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:07.506610 [ 3181 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:07.717628 [ 3300 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:08.021175 [ 4665 ] {892fe5bf-9ad6-4e73-b56f-08ab72871a9b} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_3.constraint_constant_nullable_expression_that_contains_null (d731e94d-eb01-45bf-a287-e0287606dae9) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (VIOLATED_CONSTRAINT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40678) (comment: 01721_constraints_constant_expressions.sql) (in query: INSERT INTO constraint_constant_nullable_expression_that_contains_null 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f9320f 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:13:08.023449 [ 4665 ] {892fe5bf-9ad6-4e73-b56f-08ab72871a9b} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_3.constraint_constant_nullable_expression_that_contains_null (d731e94d-eb01-45bf-a287-e0287606dae9) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f9320f 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:13:08.028578 [ 8473 ] {445e6356-9383-45ec-9870-cc50331c0f0d} 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.10508.altinitytest (altinity build)) (from [::1]:36964) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_5-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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) @ 0x0000000012e37572 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&) @ 0x0000000012e39785 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:08.097489 [ 8473 ] {445e6356-9383-45ec-9870-cc50331c0f0d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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) @ 0x0000000012e37572 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&) @ 0x0000000012e39785 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:08.261796 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:08.335984 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:08.509308 [ 3016 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:08.719647 [ 3267 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:09.271163 [ 3110 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:09.341487 [ 3338 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:09.511591 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:09.721720 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:10.273030 [ 3120 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:10.343309 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:10.513312 [ 3253 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:10.724932 [ 3301 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:11.275930 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:11.345827 [ 3202 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:11.542348 [ 3052 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:11.727458 [ 3091 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:12.279790 [ 3211 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:12.348771 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:12.548116 [ 3335 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:12.730307 [ 3256 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:13.282497 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:13.351988 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:13.556990 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:13.732793 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:14.285376 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:14.355022 [ 3415 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:14.559412 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:14.708649 [ 4665 ] {052b6295-58b9-45dc-aa93-da1264394ea3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36972) (comment: 00910_zookeeper_test_alter_compression_codecs_long.sql) (in query: SELECT * FROM alter_compression_codec2 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:14.712703 [ 4665 ] {052b6295-58b9-45dc-aa93-da1264394ea3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:14.738131 [ 3490 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:15.288277 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:15.428415 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:15.561918 [ 3187 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:15.741769 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:16.291062 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:16.436854 [ 3060 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:16.564701 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:16.749073 [ 3128 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:17.027828 [ 17857 ] {e8aa0573-e2e1-49cc-861a-ed6c712156c2} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Size of BSON document is extremely large. Expected not greater than 4777863 bytes, but current is 268435456 bytes per row. Increase the value setting 'min_chunk_bytes_for_parallel_parsing' or check your data manually, most likely BSON is malformed. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 int&) @ 0x000000000935d3ab 4. /build/src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000012ddb427 5. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb281f 6. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 7. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 9. ? @ 0x00007fd96814bac3 10. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:17.053586 [ 4665 ] {e8aa0573-e2e1-49cc-861a-ed6c712156c2} executeQuery: Code: 117. DB::Exception: Size of BSON document is extremely large. Expected not greater than 4777863 bytes, but current is 268435456 bytes per row. Increase the value setting 'min_chunk_bytes_for_parallel_parsing' or check your data manually, most likely BSON is malformed: While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47258) (comment: 02684_bson.sql) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7��QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&��QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID^WatchID��F�ӓ2qJavaEnableTitleGoodEventEventTimen$�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthmingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashv�v����CLID�WatchID���\JavaEnableTitleGoodEventEventTime� �QEventDate>CounterIDClientIP�gURegionID�UserID�s�yy��fCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID�ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY��QAgeSexIncomeInterestsRobotnessRemoteIP�=kWindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashh��9�DCLID^WatchID�/E��J�{JavaEnableTitleGoodEventEventTime�1�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime���QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID$$);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 int&) @ 0x000000000935d3ab 4. /build/src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000012ddb427 5. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb281f 6. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 7. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 9. ? @ 0x00007fd96814bac3 10. ? @ 0x00007fd9681dd850 2025.09.25 21:13:17.057484 [ 4665 ] {e8aa0573-e2e1-49cc-861a-ed6c712156c2} TCPHandler: Code: 117. DB::Exception: Size of BSON document is extremely large. Expected not greater than 4777863 bytes, but current is 268435456 bytes per row. Increase the value setting 'min_chunk_bytes_for_parallel_parsing' or check your data manually, most likely BSON is malformed: While executing ParallelParsingBlockInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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 int&) @ 0x000000000935d3ab 4. /build/src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000012ddb427 5. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb281f 6. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5cb9 7. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 9. ? @ 0x00007fd96814bac3 10. ? @ 0x00007fd9681dd850 2025.09.25 21:13:17.299375 [ 3269 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:17.443469 [ 3024 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:17.468625 [ 8473 ] {68394064-b5d5-44cc-b820-44d1583efd78} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.proto. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47264) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_5-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000012e3801f 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&) @ 0x0000000012f4bf07 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:17.479486 [ 8473 ] {68394064-b5d5-44cc-b820-44d1583efd78} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000012e3801f 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&) @ 0x0000000012f4bf07 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:17.624957 [ 3179 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:17.816993 [ 3091 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:18.262931 [ 8473 ] {31da63c4-4738-4196-a9e5-44f879e3953a} 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.10508.altinitytest (altinity build)) (from [::1]:47286) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_5-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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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) @ 0x0000000012e38ad2 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&) @ 0x0000000012f4bf07 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:18.266982 [ 8473 ] {31da63c4-4738-4196-a9e5-44f879e3953a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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) @ 0x0000000012e38ad2 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&) @ 0x0000000012f4bf07 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 @ 0x0000000012ce40aa 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 @ 0x0000000012ce35d4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d4f0 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) @ 0x000000001226dfa2 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&) @ 0x000000001226dc87 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) @ 0x0000000012261ba3 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&) @ 0x0000000013055ec2 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*) @ 0x00000000115f67ce 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&) @ 0x00000000115f72f5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8bd7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8ec 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:13:18.302186 [ 3196 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:18.456136 [ 3421 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:18.627664 [ 3373 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:18.825540 [ 3332 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:19.304790 [ 3094 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:19.458880 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:19.631491 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:19.832289 [ 2988 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:20.310634 [ 3229 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:20.461781 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:20.634581 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:20.838294 [ 3347 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:21.313073 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:21.466243 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:21.637207 [ 3081 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:21.677195 [ 7898 ] {bcf2e470-de1d-4142-a57c-877859801e46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47292) (comment: 02240_system_filesystem_cache_table.sh) (in query: SELECT uniqExact(key) FROM system.filesystem_cache), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:21.696473 [ 7898 ] {bcf2e470-de1d-4142-a57c-877859801e46} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:21.841414 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:22.315569 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:22.469099 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:22.639940 [ 3407 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:22.800261 [ 8473 ] {383e94ef-993c-4faf-acb2-93564417356d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47308) (comment: 01530_drop_database_atomic_sync.sql) (in query: drop database db_01530_atomic 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:22.802508 [ 8473 ] {383e94ef-993c-4faf-acb2-93564417356d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:22.844401 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:23.318156 [ 3131 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:23.475494 [ 3419 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:23.601826 [ 7897 ] {66dd640a-260f-4670-9c2d-4a2ccadd911d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47330) (comment: 01530_drop_database_atomic_sync.sql) (in query: drop database if exists db_01530_atomic 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:23.605494 [ 7897 ] {66dd640a-260f-4670-9c2d-4a2ccadd911d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:23.609515 [ 4665 ] {608599a6-f5cd-4bcd-89ea-ae2847057c8b} executeQuery: Code: 252. DB::Exception: Too many parts (10 with average size of 83.00 B) in table 'test_3.too_many_parts (f6fd43de-badf-4386-8ab3-9dae169421e4)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47270) (comment: 01603_insert_select_too_many_parts.sql) (in query: -- exception is thrown if threshold is exceeded on new INSERT. INSERT INTO too_many_parts 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 12. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:23.626376 [ 4665 ] {608599a6-f5cd-4bcd-89ea-ae2847057c8b} TCPHandler: Code: 252. DB::Exception: Too many parts (10 with average size of 83.00 B) in table 'test_3.too_many_parts (f6fd43de-badf-4386-8ab3-9dae169421e4)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, ReadableSize&&, String&&) @ 0x00000000127f934b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba7d4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 12. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:23.645021 [ 2969 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:23.860625 [ 3437 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:24.321323 [ 3238 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:24.481117 [ 3441 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:24.648245 [ 3408 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:24.866765 [ 3231 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:24.903902 [ 2929 ] {a25a5f0d-7dd7-4051-9026-d42cefae75b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51996) (comment: 03173_set_transformed_partition_pruning.sql) (in query: SELECT ProfileEvents['SelectedParts'] FROM system.query_log WHERE type = 'QueryFinish' AND current_database = currentDatabase() AND log_comment = '03173_nested_function_lc';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:13:24.938638 [ 2929 ] {a25a5f0d-7dd7-4051-9026-d42cefae75b6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.370169 [ 3200 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:25.485452 [ 3330 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:25.561016 [ 3299 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011182184 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182677 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:25.651717 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:25.701904 [ 7902 ] {1e68b275-702f-4352-96d7-a4b193b20149} executeQuery: Code: 344. DB::Exception: Experimental full-text index feature is not enabled (the setting 'allow_experimental_full_text_index'). (SUPPORT_IS_DISABLED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47356) (comment: 02346_inverted_index_experimental_flag.sql) (in query: CREATE TABLE tab (`id` UInt32, `str` String, INDEX idx str TYPE full_text(0) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 17676, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 302355836, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 4535369, merge_max_block_size = 11955, 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 = 2932020, index_granularity_bytes = 20833520, concurrent_part_removal_threshold = 60, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 36170, primary_key_compress_block_size = 98947), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011552c2a 5. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.706130 [ 7902 ] {1e68b275-702f-4352-96d7-a4b193b20149} TCPHandler: Code: 344. DB::Exception: Experimental full-text index feature is not enabled (the setting 'allow_experimental_full_text_index'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011552c2a 5. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.806368 [ 7902 ] {61a6bca1-2726-4d78-9a6c-10a2a2ff8b80} executeQuery: Code: 127. DB::Exception: Please use index type 'full_text' instead of 'inverted'. (ILLEGAL_INDEX) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47356) (comment: 02346_inverted_index_experimental_flag.sql) (in query: CREATE TABLE tab (`id` UInt32, `str` String, INDEX idx str TYPE inverted(0) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 17676, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 302355836, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 4535369, merge_max_block_size = 11955, 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 = 2932020, index_granularity_bytes = 20833520, concurrent_part_removal_threshold = 60, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 36170, primary_key_compress_block_size = 98947), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:788: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011552b9c 5. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.809621 [ 7902 ] {61a6bca1-2726-4d78-9a6c-10a2a2ff8b80} TCPHandler: Code: 127. DB::Exception: Please use index type 'full_text' instead of 'inverted'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:788: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011552b9c 5. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.869335 [ 3080 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:25.944888 [ 7902 ] {6d4a963b-1305-4e12-bccd-152983c03412} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47356) (comment: 02346_inverted_index_experimental_flag.sql) (in query: CREATE TABLE tab (`id` UInt32, `str` String, INDEX idx str TYPE full_text(0) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 17676, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 302355836, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 4535369, merge_max_block_size = 11955, 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 = 2932020, index_granularity_bytes = 20833520, concurrent_part_removal_threshold = 60, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 36170, primary_key_compress_block_size = 98947), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:25.947685 [ 7902 ] {6d4a963b-1305-4e12-bccd-152983c03412} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:26.230384 [ 7932 ] {0c318bac-2a68-4a4b-b821-579111159edd} executeQuery: Code: 57. DB::Exception: Table test_3.set already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47348) (comment: 01493_storage_set_persistency.sql) (in query: CREATE TABLE set (val UInt64) ENGINE = Set() 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:26.237795 [ 7932 ] {0c318bac-2a68-4a4b-b821-579111159edd} TCPHandler: Code: 57. DB::Exception: Table test_3.set 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:26.376719 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:26.489242 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:26.654374 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:26.719755 [ 7932 ] {05ffc934-7249-4401-999a-80eace07dd23} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33184) (comment: 01050_window_view_parser_tumble.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:26.724442 [ 7932 ] {05ffc934-7249-4401-999a-80eace07dd23} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:26.871663 [ 3070 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:27.379053 [ 3228 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:27.491648 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:27.522693 [ 7902 ] {d286d5dd-8bd5-4681-a270-67e17692b38f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT 1 WINDOW x AS (PARTITION BY x). (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33214) (comment: 02901_analyzer_recursive_window.sql) (in query: SELECT 1 WINDOW x AS (PARTITION 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ac29 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ca 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:13:27.524485 [ 7902 ] {d286d5dd-8bd5-4681-a270-67e17692b38f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT 1 WINDOW x AS (PARTITION BY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ac29 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ca 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:13:27.664044 [ 3258 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:27.873287 [ 3446 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:28.381059 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:28.493176 [ 3335 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:28.667994 [ 3035 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:28.874754 [ 3210 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:28.977970 [ 7897 ] {ec97a80e-babf-4904-8754-7843ae2d310e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47346) (comment: 01530_drop_database_atomic_sync.sql) (in query: drop database db_01530_atomic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:28.979282 [ 7897 ] {ec97a80e-babf-4904-8754-7843ae2d310e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:29.386664 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:29.495670 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:29.670068 [ 3368 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:29.806784 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_1_94_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:29.876753 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:30.388667 [ 3011 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:30.500501 [ 3143 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:30.674924 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:30.878462 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:31.304901 [ 8202 ] {e6436a92-a7a6-4135-85c9-03abbce46794} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43836) (comment: 02240_system_filesystem_cache_table.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_srkp9cht`.`test_02240_storage_policy` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:13:31.394181 [ 3416 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:31.396190 [ 8202 ] {e6436a92-a7a6-4135-85c9-03abbce46794} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:13:31.440263 [ 7898 ] {a55fa181-f6b7-45c9-8e50-422f286485c7} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33264) (comment: 02240_system_filesystem_cache_table.sh) (in query: SELECT * FROM test_02240_storage_policy 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:13:31.448161 [ 7898 ] {a55fa181-f6b7-45c9-8e50-422f286485c7} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:13:31.506712 [ 3383 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:31.677337 [ 3017 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:31.880434 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:32.378075 [ 7897 ] {d43a9afd-8319-450d-a545-250cfe5d3f88} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33250) (comment: 01530_drop_database_atomic_sync.sql) (in query: drop database db_01530_atomic 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:32.380942 [ 7897 ] {d43a9afd-8319-450d-a545-250cfe5d3f88} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:32.401555 [ 3118 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:32.460621 [ 7932 ] {a84313d7-465c-4d16-a419-3b5549fecb40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33198) (comment: 02366_kql_summarize.sql) (in query: Customers | summarize count(), min(Age), max(Age), avg(Age), sum(Age);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:13:32.474310 [ 7932 ] {a84313d7-465c-4d16-a419-3b5549fecb40} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:13:32.511038 [ 3152 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:32.682320 [ 3475 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:32.884157 [ 3247 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:33.403420 [ 3432 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:33.443415 [ 7902 ] {8b73918b-90b6-408e-a84b-bed7196d9a37} executeQuery: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%X: %X', 123.123). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33280) (comment: 03203_function_printf.sql) (in query: select printf('%%X: %X', 123.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.445187 [ 7902 ] {8b73918b-90b6-408e-a84b-bed7196d9a37} TCPHandler: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%X: %X', 123.123). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.513205 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:33.560555 [ 7902 ] {e60cddd2-2361-41c1-a001-7486cf0f596d} executeQuery: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%A: %A', 'abc'). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33280) (comment: 03203_function_printf.sql) (in query: select printf('%%A: %A', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.563828 [ 7902 ] {e60cddd2-2361-41c1-a001-7486cf0f596d} TCPHandler: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%A: %A', 'abc'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.599009 [ 7902 ] {cb6e2af4-3f82-4a52-9a58-4af5ce8c8627} executeQuery: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%s: %s', 100). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33280) (comment: 03203_function_printf.sql) (in query: select printf('%%s: %s', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.602339 [ 7902 ] {cb6e2af4-3f82-4a52-9a58-4af5ce8c8627} TCPHandler: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%s: %s', 100). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.631983 [ 7902 ] {1efe2c47-c6f7-4282-ab93-9f9888571f9a} executeQuery: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%n: %n', 100). (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33280) (comment: 03203_function_printf.sql) (in query: select printf('%%n: %n', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.647048 [ 7902 ] {1efe2c47-c6f7-4282-ab93-9f9888571f9a} TCPHandler: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid type specifier: In scope SELECT printf('%%n: %n', 100). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000b4eee8b 4. /build/src/Functions/printf.cpp:0: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4eb310 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&) @ 0x0000000011050d10 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:13:33.684123 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:33.888654 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.348377 [ 3588 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_1_94_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.405307 [ 3409 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.547045 [ 3331 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.586742 [ 7902 ] {feb975b4-6367-4bd6-a6ee-6b369b429dde} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n') settings input_format_tsv_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000012f53f22 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:34.620003 [ 7902 ] {feb975b4-6367-4bd6-a6ee-6b369b429dde} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000012f53f22 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:34.687624 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.870324 [ 7902 ] {28bd95bf-19f5-40de-a6af-cc98f5b0d639} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n1\t2\n') settings input_format_tsv_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000012f53f22 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:34.871956 [ 7902 ] {28bd95bf-19f5-40de-a6af-cc98f5b0d639} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000012f53f22 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:34.890373 [ 3070 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:34.945852 [ 7902 ] {290aa282-38ee-4342-9204-a40de9a85197} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n') settings input_format_csv_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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() @ 0x0000000012e0c987 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:34.950165 [ 7902 ] {290aa282-38ee-4342-9204-a40de9a85197} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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() @ 0x0000000012e0c987 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.305185 [ 7902 ] {17a41db1-01bd-494b-8448-841696a0bcad} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n1,2\n') settings input_format_csv_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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() @ 0x0000000012e0c987 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.315936 [ 7902 ] {17a41db1-01bd-494b-8448-841696a0bcad} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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() @ 0x0000000012e0c987 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&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.407383 [ 3019 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:35.621719 [ 3363 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:35.653649 [ 7902 ] {ac15bde5-314b-4098-b605-9b5008ebb677} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.656158 [ 7902 ] {ac15bde5-314b-4098-b605-9b5008ebb677} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.689690 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:35.903182 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:35.909767 [ 7902 ] {dfacfcb0-ddb5-4a47-b158-2288a632cba7} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33320) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:35.913133 [ 7902 ] {dfacfcb0-ddb5-4a47-b158-2288a632cba7} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/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/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de5e7d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6ecd9 16. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ba8 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1128 18. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:36.413107 [ 3392 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:36.625840 [ 3099 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:36.771780 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:36.905604 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:37.247944 [ 3082 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:37.416220 [ 3105 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:37.628050 [ 3311 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:37.773997 [ 3198 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:37.815285 [ 7932 ] {6be3460c-2cca-4b77-a44e-e468b4e3b395} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46830) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(18446744073709551615, 0.9998999834060669);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:37.823662 [ 7932 ] {6be3460c-2cca-4b77-a44e-e468b4e3b395} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:37.883262 [ 7932 ] {d00cbaa9-b303-44cd-9f15-5922b0fd961b} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46830) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:37.888664 [ 7932 ] {d00cbaa9-b303-44cd-9f15-5922b0fd961b} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:101: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x00000000095dd07b 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009738c23 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>(auto const&) const @ 0x000000000972fc07 7. /build/src/Functions/castTypeToEither.h:0: 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&&) @ 0x000000000972f847 8. /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&&) @ 0x0000000009710103 9. /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 10. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 11. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 12. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 13. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 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 @ 0x0000000007b6871a 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&) @ 0x0000000011050d10 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:13:37.907820 [ 3476 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:38.249933 [ 3069 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:38.417992 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:38.607970 [ 7902 ] {e6c64b8e-24b8-4e2a-9e59-f49be60d4218} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46848) (comment: 03224_json_merges_new_type_in_shared_data.sql) (in query: CREATE TABLE test (`json` JSON(max_dynamic_paths = 1)) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 51231, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 56, min_bytes_for_full_part_storage = 366621802, compact_parts_max_bytes_to_buffer = 404257973, compact_parts_max_granules_to_buffer = 224, compact_parts_merge_max_bytes_to_prefetch_part = 16615748, merge_max_block_size = 14637, old_parts_lifetime = 445., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 45741, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10289207182, index_granularity_bytes = 9350971, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 88911, primary_key_compress_block_size = 16992), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:38.613667 [ 7902 ] {e6c64b8e-24b8-4e2a-9e59-f49be60d4218} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:13:38.641361 [ 3041 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:38.834001 [ 3353 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:38.910098 [ 3011 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:39.256691 [ 3190 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:39.420750 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:39.644374 [ 3215 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:39.836458 [ 3243 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:39.917061 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:40.258565 [ 3387 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:40.422691 [ 3329 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:40.647154 [ 3119 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:40.841131 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:40.862137 [ 7902 ] {4703a959-67be-4009-b7bc-fcd5325e4005} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46870) (comment: 01748_partition_id_pruning.sql) (in query: CREATE TABLE x (`i` int, `j` int) ENGINE = MergeTree PARTITION BY i ORDER BY j SETTINGS index_granularity = 1, min_bytes_for_wide_part = 180678198, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 127906173, compact_parts_max_granules_to_buffer = 86, compact_parts_merge_max_bytes_to_prefetch_part = 8775895, merge_max_block_size = 1022, 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 = 65, min_merge_bytes_to_use_direct_io = 4958986965, index_granularity_bytes = 13500592, concurrent_part_removal_threshold = 15, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 42110, primary_key_compress_block_size = 96794), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:13:40.891380 [ 7902 ] {4703a959-67be-4009-b7bc-fcd5325e4005} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:13:40.919378 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:41.260592 [ 3123 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:41.469054 [ 3410 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:41.648986 [ 3287 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:41.842893 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:41.920946 [ 3143 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:42.262841 [ 3196 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:42.474121 [ 3292 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:42.651634 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:42.848264 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:42.922873 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:43.265264 [ 3431 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:43.477318 [ 3139 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:43.653326 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:43.850719 [ 3490 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:43.933017 [ 3222 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:44.268067 [ 3305 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:44.480222 [ 3441 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:44.657106 [ 3001 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:44.853097 [ 3218 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:44.940650 [ 3163 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:45.270688 [ 3323 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:45.486450 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:45.660059 [ 2995 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:45.859852 [ 3411 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:45.943030 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:46.276038 [ 3016 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:46.493607 [ 3230 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:46.666390 [ 3013 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:46.862417 [ 3274 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:46.945291 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:47.278265 [ 3265 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:47.497057 [ 3281 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:47.674043 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:47.817677 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:47.867866 [ 3433 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:47.952331 [ 3145 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:48.284390 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:48.499548 [ 3134 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:48.575250 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:48.678144 [ 3162 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:48.870438 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:48.959380 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:49.323994 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:49.515535 [ 3251 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:49.680850 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:49.808442 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:49.873583 [ 3243 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:49.962841 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:50.326425 [ 3176 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:50.524045 [ 3364 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:50.683227 [ 3475 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:50.876466 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:50.959723 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:50.983858 [ 3320 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:51.333180 [ 3229 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:51.526964 [ 3333 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:51.691438 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:51.879221 [ 3454 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:51.986721 [ 3031 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:52.196636 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:52.335968 [ 3131 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:52.530017 [ 3230 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:52.694237 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:52.881880 [ 3247 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:52.989515 [ 3187 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:53.397397 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:53.414037 [ 3432 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:53.534021 [ 3248 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:53.697911 [ 3277 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:53.939139 [ 3072 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:53.992341 [ 3297 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:54.416434 [ 3194 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:54.549183 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:54.549130 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:54.700366 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:54.945083 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:54.998327 [ 3184 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:55.418924 [ 3191 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:55.552468 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:55.640938 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:55.705618 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.000792 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.022459 [ 3374 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.421451 [ 3318 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.554807 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.708234 [ 3451 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:56.796613 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:57.003749 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:57.027442 [ 2998 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:57.423326 [ 3489 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:57.557413 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:57.691129 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:57.710282 [ 3487 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.006216 [ 3275 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.030082 [ 3321 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.434098 [ 3042 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.559893 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.712978 [ 3300 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:58.929962 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:13:59.015032 [ 3414 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:59.033896 [ 3381 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:59.436418 [ 3057 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:59.564440 [ 3113 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:59.715541 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:13:59.840137 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:00.017052 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:00.036306 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:00.492213 [ 3402 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:00.566803 [ 3279 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:00.718215 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:00.970391 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:01.019523 [ 3328 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:01.042126 [ 3362 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:01.534171 [ 3219 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:01.570802 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:01.736387 [ 3132 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:02.021966 [ 3306 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:02.044455 [ 3214 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:02.070857 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:02.536483 [ 3268 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:02.573720 [ 2982 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:02.738995 [ 3189 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.024756 [ 3391 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.046716 [ 3288 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.132143 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.191985 [ 7615 ] {17f15144-cd2e-40e7-958b-59ee3de9dcb2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59454) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.193350 [ 7615 ] {17f15144-cd2e-40e7-958b-59ee3de9dcb2} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.320650 [ 5326 ] {8cba39ad-0f71-4af8-891a-ee37741f2343} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44962) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.322194 [ 5326 ] {8cba39ad-0f71-4af8-891a-ee37741f2343} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.399602 [ 4665 ] {6bfa00d2-8f65-4652-9158-8d6684982bc5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44978) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.402153 [ 4665 ] {6bfa00d2-8f65-4652-9158-8d6684982bc5} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.541822 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.569079 [ 8473 ] {ae92569f-5159-4bca-ac33-c197e2f47221} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44982) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_6glfiu5t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.574751 [ 8473 ] {ae92569f-5159-4bca-ac33-c197e2f47221} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.577433 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.741212 [ 3067 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:03.951248 [ 8473 ] {0a5a4587-a1b1-41a7-8a96-62e11bc05369} executeQuery: Code: 57. DB::Exception: Table test_srkp9cht.test_02240_storage_policy already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59070) (comment: 02240_system_filesystem_cache_table.sh) (in query: CREATE TABLE test_02240_storage_policy (key UInt32, value String) Engine=MergeTree() ORDER BY key SETTINGS storage_policy='local_cache', min_bytes_for_wide_part = 1000000, compress_marks=false, compress_primary_key=false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:03.996139 [ 8473 ] {0a5a4587-a1b1-41a7-8a96-62e11bc05369} TCPHandler: Code: 57. DB::Exception: Table test_srkp9cht.test_02240_storage_policy 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:04.027788 [ 3435 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:04.055262 [ 3482 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:04.352235 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:04.552744 [ 3382 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:04.580307 [ 3335 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:04.743753 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:05.035750 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:05.057967 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:05.160014 [ 8473 ] {97141f72-b6d9-43a8-a82f-e078d7a298d1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59098) (comment: 02240_system_filesystem_cache_table.sh) (in query: INSERT INTO test_02240_storage_policy SELECT number, toString(number) FROM numbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010641267 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001064108f 9. /build/contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x00000000106d91ab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106c7929 11. /build/src/IO/WriteBufferFromS3.cpp:180: DB::WriteBufferFromS3::preFinalize() @ 0x00000000106c72d6 12. /build/src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000010f3a8f5 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x0000000012830411 14. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000012830abf 15. /build/contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000001295326a 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000129869a7 17. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 19. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 20. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 28. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 2025.09.25 21:14:05.181712 [ 8473 ] {97141f72-b6d9-43a8-a82f-e078d7a298d1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010641267 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001064108f 9. /build/contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x00000000106d91ab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106c7929 11. /build/src/IO/WriteBufferFromS3.cpp:180: DB::WriteBufferFromS3::preFinalize() @ 0x00000000106c72d6 12. /build/src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000010f3a8f5 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x0000000012830411 14. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:450: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000012830abf 15. /build/contrib/llvm-project/libcxx/include/__hash_table:1727: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000001295326a 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000129869a7 17. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 19. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 20. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 28. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 2025.09.25 21:14:05.561783 [ 3471 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:05.590669 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:05.634539 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:05.750051 [ 2974 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.038704 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.071001 [ 3092 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.568576 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.594492 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.752920 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:06.888078 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:07.041344 [ 3190 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:07.073665 [ 2984 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:07.578171 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:07.596968 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:07.755442 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:08.044051 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:08.079527 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:08.185476 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:08.580564 [ 3285 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:08.600830 [ 3271 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:08.757815 [ 3048 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:09.046155 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:09.081416 [ 3291 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:09.191956 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:09.555261 [ 5600 ] {24d8c5ba-662c-44e6-aafe-86bf18f0c86c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=15): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59000) (comment: 01035_avg.sql) (in query: SELECT avg(i8), avg(i16), avg(i32), avg(i64), avg(i128), avg(i256), avg(u8), avg(u16), avg(u32), avg(u64), avg(u128), avg(u256), avg(f32), avg(f64), avg(d32), avg(d64), avg(d128), avg(d256) FROM test_01035_avg;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:14:09.582012 [ 3195 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:09.603541 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:09.648391 [ 5600 ] {24d8c5ba-662c-44e6-aafe-86bf18f0c86c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=15): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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.09.25 21:14:09.762287 [ 3365 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:10.053745 [ 3362 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:10.084122 [ 3159 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:10.161851 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:10.270411 [ 7898 ] {fb9f6673-d9c3-45b6-adbf-39f172e0a937} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57298) (comment: 02921_database_filesystem_path_check.sql) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010da0709 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&) @ 0x0000000010da52d8 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&) @ 0x0000000010da29ce 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e876 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e2eb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154a8dc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:10.275204 [ 7898 ] {fb9f6673-d9c3-45b6-adbf-39f172e0a937} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010da0709 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&) @ 0x0000000010da52d8 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&) @ 0x0000000010da29ce 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e876 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e2eb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154a8dc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:10.307771 [ 7898 ] {e425e22d-64e0-48b9-9a81-78a50691b241} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57298) (comment: 02921_database_filesystem_path_check.sql) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010da0709 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&) @ 0x0000000010da52d8 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&) @ 0x0000000010da29ce 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e876 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e2eb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154a8dc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:10.310301 [ 7898 ] {e425e22d-64e0-48b9-9a81-78a50691b241} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x0000000010da0709 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&) @ 0x0000000010da52d8 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&) @ 0x0000000010da29ce 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e876 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e2eb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154a8dc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:10.605685 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:10.667702 [ 3488 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:10.786179 [ 2974 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:11.112501 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:11.113324 [ 3071 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:11.419145 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:11.611621 [ 3400 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:11.670392 [ 3289 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:11.794962 [ 3241 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:12.115143 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:12.115749 [ 3077 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:12.565313 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:12.618001 [ 3106 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:12.673331 [ 3325 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:12.799233 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:13.117953 [ 3136 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:13.118651 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:13.628002 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:13.675009 [ 3475 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:13.696095 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:13.805587 [ 3036 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.120591 [ 3350 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.186712 [ 3463 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.631024 [ 3311 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.677136 [ 3366 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.808570 [ 3201 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:14.898971 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:15.122199 [ 3140 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:15.190241 [ 3076 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:15.634067 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:15.679499 [ 3447 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:15.812661 [ 3365 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:16.124372 [ 3298 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:16.150075 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:16.197391 [ 3307 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:16.266299 [ 7932 ] {a2e601c4-f26b-4871-acad-21a48cbd4799} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57398) (comment: 02808_filesystem_cache_drop_query.sh) (in query: CREATE TABLE test (a Int32, b String) ENGINE = MergeTree() ORDER BY tuple() SETTINGS disk = disk(name = '02808_filesystem_cache_drop_query_test_13', type = cache, max_size = '100Ki', path = 02808_filesystem_cache_drop_query_test_13, disk = s3_disk);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:16.288936 [ 7932 ] {a2e601c4-f26b-4871-acad-21a48cbd4799} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:16.636731 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:16.682754 [ 3452 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:16.815306 [ 3033 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.025083 [ 8473 ] {1f46debc-226d-4a23-af8b-9f11c143968c} executeQuery: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40440) (comment: 02808_filesystem_cache_drop_query.sh) (in query: SYSTEM DROP FILESYSTEM CACHE '02808_filesystem_cache_drop_query_test_13' KEY kek;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:17.046856 [ 8473 ] {1f46debc-226d-4a23-af8b-9f11c143968c} TCPHandler: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:17.136070 [ 3169 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.200262 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.321419 [ 7933 ] {13c8e938-9f01-493b-9f3e-19f14c1a047e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39558) (comment: 02240_system_filesystem_cache_table.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_srkp9cht`.`test_02240_storage_policy` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:17.338917 [ 7933 ] {13c8e938-9f01-493b-9f3e-19f14c1a047e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:17.398752 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:17.405248 [ 7932 ] {b8f44d6d-b744-4ddc-a0d7-dccf023452f9} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40456) (comment: 02240_system_filesystem_cache_table.sh) (in query: SELECT * FROM test_02240_storage_policy 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:14:17.407761 [ 7937 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38466, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.409720 [ 7932 ] {b8f44d6d-b744-4ddc-a0d7-dccf023452f9} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:14:17.410459 [ 4994 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50564, local: [::ffff:127.0.0.8]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.533080 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8f25176d-6bf0-484f-b27f-d635da64b3f4::202509_82_87_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.638878 [ 2969 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.688103 [ 3434 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:17.817792 [ 3332 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:18.149613 [ 3457 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:18.202571 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:18.602230 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:18.645116 [ 3408 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:18.690091 [ 3035 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:18.819922 [ 3353 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:19.155211 [ 3423 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:19.204935 [ 3276 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:19.647712 [ 3283 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:19.692403 [ 3487 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:19.797506 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:19.822201 [ 3398 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.157938 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.210326 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.650261 [ 3166 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.694603 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.824812 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:20.951426 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:21.159679 [ 3162 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:21.216219 [ 3107 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:21.653047 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:21.697101 [ 3267 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:21.827228 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:22.130723 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:22.164342 [ 3312 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:22.218495 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:22.655573 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:22.702612 [ 3372 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:22.832628 [ 3051 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:23.166735 [ 3069 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:23.224396 [ 3182 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:23.313392 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:23.657344 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:23.704220 [ 3048 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:23.834870 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:24.168447 [ 3078 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:24.188104 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:24.226133 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:24.658953 [ 3093 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:24.705750 [ 3415 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:24.839339 [ 2985 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.073007 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:25.170132 [ 3323 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.227791 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.660603 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.707348 [ 2978 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.841177 [ 3085 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:25.942833 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:26.171720 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:26.229954 [ 3018 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:26.662575 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:26.709402 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:26.843514 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:26.895186 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:27.174141 [ 3219 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:27.232088 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:27.665177 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:27.718230 [ 3385 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:27.846164 [ 3273 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.033154 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:28.177518 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.237447 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.667265 [ 3358 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.722872 [ 3142 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.849163 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:28.997128 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:29.180463 [ 2979 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:29.242839 [ 3065 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:29.708131 [ 3289 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:29.726546 [ 3009 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:29.851699 [ 3480 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:30.123373 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:30.183839 [ 3351 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:30.186215 [ 7897 ] {8bf62d52-7300-4036-9696-8d8489035125} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33382) (comment: 02950_parallel_replicas_used_count.sql) (in query: SELECT ProfileEvents['ParallelReplicasUsedCount'] > 0 FROM system.query_log WHERE type = 'QueryFinish' AND query_id IN (SELECT query_id FROM system.query_log WHERE current_database = currentDatabase() AND log_comment = '02950_parallel_replicas_used_replicas_count_2' AND type = 'QueryFinish' AND initial_query_id = query_id) SETTINGS enable_parallel_replicas=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:30.193290 [ 7897 ] {8bf62d52-7300-4036-9696-8d8489035125} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:30.246044 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:30.645004 [ 8473 ] {2c50be4a-1a11-4ff4-a85d-862fe46c0333} executeQuery: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58572) (comment: 02808_filesystem_cache_drop_query.sh) (in query: SYSTEM DROP FILESYSTEM CACHE '02808_filesystem_cache_drop_query_test_13' KEY OFFSET ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:30.659427 [ 8473 ] {2c50be4a-1a11-4ff4-a85d-862fe46c0333} TCPHandler: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:30.723224 [ 3056 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:30.731730 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:30.861238 [ 3398 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:31.075616 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:31.185395 [ 3463 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:31.247995 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:31.725120 [ 3045 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:31.733890 [ 3301 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:31.863450 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:32.147085 [ 7932 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:32.186764 [ 3263 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:32.254394 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:32.727277 [ 3293 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:32.736215 [ 3091 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:32.866530 [ 2975 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:33.270815 [ 3082 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:33.271597 [ 3257 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:33.339063 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:33.732061 [ 3189 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:33.751457 [ 3430 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:33.880816 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:34.273180 [ 3453 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:34.273899 [ 3294 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:34.464913 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:34.734896 [ 3132 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:34.754079 [ 3260 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:34.891716 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:35.274842 [ 3425 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:35.275669 [ 3110 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:35.401264 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:35.737512 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:35.756960 [ 3198 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:35.897473 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:36.276879 [ 3190 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:36.277678 [ 3078 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:36.558562 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:36.740189 [ 3241 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:36.760661 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:36.901463 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:37.279666 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:37.280107 [ 3123 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:37.743003 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:37.763233 [ 3093 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:37.849674 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:37.908029 [ 3397 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:38.282277 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:38.282458 [ 3094 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:38.746134 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:38.769210 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:38.910988 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:39.057551 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:39.285852 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:39.289184 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:39.748874 [ 2988 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:39.770756 [ 3422 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:39.918946 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:40.211200 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:40.288022 [ 3338 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:40.291793 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:40.751346 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:40.776704 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:40.924238 [ 3439 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:41.247759 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:41.293678 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:41.294984 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:41.459772 [ 5326 ] {8a104ea3-3129-4b86-82dc-13874fdfe0f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58622) (comment: 00981_topK_topKWeighted_long.sql) (in query: SELECT arraySort(topKWeighted(10)(val1, val2)) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:41.464805 [ 5326 ] {8a104ea3-3129-4b86-82dc-13874fdfe0f4} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:41.755624 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:41.778579 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:41.926311 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:42.254961 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:42.296120 [ 2982 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:42.297368 [ 3102 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:42.763795 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:42.813838 [ 3130 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:42.928787 [ 3216 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:43.298948 [ 3388 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:43.299851 [ 3354 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:43.328666 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:43.807148 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:43.815626 [ 3433 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:43.932362 [ 3401 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.257281 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:44.300953 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.301470 [ 3328 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.758909 [ 3014 ] {} test_3.rmt1 (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1/columns.txt: , errno: 2, strerror: No such file or directory. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e455 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e262 5. ? @ 0x00000000104cdbf0 6. /build/src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x00000000104cdc22 7. /build/src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000104c9440 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x00000000104c8fdf 9. /build/src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x00000000104c8ed4 10. /build/src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000010ef8fce 11. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000126b87e8 12. /build/src/Storages/MergeTree/checkDataPart.cpp:0: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x0000000012a678be 13. /build/src/Storages/MergeTree/checkDataPart.cpp:419: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x0000000012a674e2 14. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x00000000129ea1c9 15. /build/src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x00000000129ecb5b 16. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x00000000129eecbc 17. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 19. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.759739 [ 3014 ] {} test_3.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 looks broken. Removing it and will try to fetch. 2025.09.25 21:14:44.760605 [ 3014 ] {} test_3.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.09.25 21:14:44.764627 [ 3014 ] {} test_3.rmt1 (47d5afb1-1918-4c91-8f18-80a15684216b): Detached 3 parts covered by broken part all_0_1_1: all_0_1_1, all_0_0_0, all_1_1_0 2025.09.25 21:14:44.809308 [ 3423 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.818717 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.829190 [ 2929 ] {5e9af246-7f7b-4e7b-914e-92c55d090cb6} executeQuery: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1/ in table test_3.rmt1 (47d5afb1-1918-4c91-8f18-80a15684216b) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48150) (comment: 02369_lost_part_intersecting_merges.sh) (in query: select * from rmt1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e455 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e262 5. ? @ 0x00000000104cdbf0 6. /build/src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x00000000104cdc22 7. /build/src/IO/AsynchronousReadBufferFromFile.h:75: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000104caef2 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x00000000104c907e 9. /build/src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x00000000104c8ed4 10. /build/src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000010ef8fce 11. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000126b87e8 12. /build/src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::init() @ 0x00000000128f1a85 13. /build/src/Storages/MergeTree/MergeTreeReaderStream.cpp:172: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x00000000128f2c0f 14. /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>>&) @ 0x00000000128ef6e4 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 19. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 20. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 21. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 28. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 2025.09.25 21:14:44.839674 [ 2929 ] {5e9af246-7f7b-4e7b-914e-92c55d090cb6} TCPHandler: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1/ in table test_3.rmt1 (47d5afb1-1918-4c91-8f18-80a15684216b) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e455 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e262 5. ? @ 0x00000000104cdbf0 6. /build/src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x00000000104cdc22 7. /build/src/IO/AsynchronousReadBufferFromFile.h:75: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000104caef2 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x00000000104c907e 9. /build/src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x00000000104c8ed4 10. /build/src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000010ef8fce 11. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000126b87e8 12. /build/src/Storages/MergeTree/MergeTreeReaderStream.cpp:0: DB::MergeTreeReaderStream::init() @ 0x00000000128f1a85 13. /build/src/Storages/MergeTree/MergeTreeReaderStream.cpp:172: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x00000000128f2c0f 14. /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>>&) @ 0x00000000128ef6e4 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 19. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 20. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 21. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 28. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 2025.09.25 21:14:44.934406 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:44.974682 [ 3163 ] {} test_3.rmt1 (47d5afb1-1918-4c91-8f18-80a15684216b): Directory /var/lib/clickhouse/store/47d/47d5afb1-1918-4c91-8f18-80a15684216b/all_0_1_1 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.09.25 21:14:45.227335 [ 7933 ] {26257be9-7a11-47b0-b68d-8f86c0dd1c8d} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, enable_parallel_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48134) (comment: 02861_index_set_incorrect_args.sql) (in query: SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas=2, parallel_replicas_for_non_replicated_merge_tree=1, enable_parallel_replicas=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000078c4318 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103269a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:14:45.232638 [ 7933 ] {26257be9-7a11-47b0-b68d-8f86c0dd1c8d} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, enable_parallel_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000078c4318 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103269a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:14:45.239277 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:45.303448 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:45.306409 [ 3209 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:45.358179 [ 7937 ] {0015c49f-cc31-4144-8533-14887c434108} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50824) (comment: 02861_index_set_incorrect_args.sql) (in query: DROP DATABASE IF EXISTS test_mtbutl8d ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:14:45.362006 [ 7937 ] {0015c49f-cc31-4144-8533-14887c434108} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:45.812354 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:45.821135 [ 3359 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:45.937628 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.308729 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.315931 [ 3254 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.440812 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:46.818213 [ 3033 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.828610 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.867450 [ 5600 ] {a963c95b-745f-461d-86b1-228d6ebc7404} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48054) (comment: 02808_filesystem_cache_drop_query.sh) (in query: SELECT count() FROM system.filesystem_cache WHERE 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:46.940350 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:46.956226 [ 5600 ] {a963c95b-745f-461d-86b1-228d6ebc7404} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.315639 [ 3007 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:47.318208 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:47.341231 [ 7937 ] {17ee4d6e-1cea-4791-8064-f91ec56ff208} executeQuery: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49544) (comment: 02808_filesystem_cache_drop_query.sh) (in query: SYSTEM DROP FILESYSTEM CACHE '02808_filesystem_cache_drop_query_test_13' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.440885 [ 7937 ] {17ee4d6e-1cea-4791-8064-f91ec56ff208} TCPHandler: Code: 36. DB::Exception: There is no cache by name: 02808_filesystem_cache_drop_query_test_13. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Cache/FileCacheFactory.cpp:132: DB::FileCacheFactory::getByName(String const&) @ 0x00000000119a0066 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:414: DB::InterpreterSystemQuery::execute() @ 0x000000001193c35d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.566476 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.822598 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:47.831450 [ 3422 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:47.860192 [ 7933 ] {32d17e7c-2cae-4fb9-b1a4-4792693fc13b} 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.10508.altinitytest (altinity build)) (from [::1]:49552) (comment: 02369_lost_part_intersecting_merges.sh) (in query: attach table rmt1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012788da1 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000001278ac51 10. /build/contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000012346bc5 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000012a752d5 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713a2 13. /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 @ 0x00000000122534a7 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.880191 [ 7933 ] {32d17e7c-2cae-4fb9-b1a4-4792693fc13b} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012788da1 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000001278ac51 10. /build/contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000012346bc5 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000012a752d5 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713a2 13. /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 @ 0x00000000122534a7 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:47.943458 [ 3319 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:48.317812 [ 3396 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:48.320624 [ 3229 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:48.615935 [ 7933 ] {e4c4fe2b-d682-4496-878f-ecaa8ca72efa} executeQuery: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49598) (comment: 02369_lost_part_intersecting_merges.sh) (in query: insert into rmt1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:48.620264 [ 7933 ] {e4c4fe2b-d682-4496-878f-ecaa8ca72efa} TCPHandler: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:48.693447 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:48.825331 [ 3347 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:48.836171 [ 2999 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:48.948870 [ 3130 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.320403 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.322763 [ 3239 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.827867 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.843368 [ 3480 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.853367 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:49.951632 [ 3262 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:49.995724 [ 2929 ] {515d55e4-4d05-4249-9d2f-0b8dc5bb052e} executeQuery: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49642) (comment: 02369_lost_part_intersecting_merges.sh) (in query: system sync replica rmt1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x00000000119453fb 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000001193c748 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.003695 [ 2929 ] {515d55e4-4d05-4249-9d2f-0b8dc5bb052e} TCPHandler: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x00000000119453fb 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000001193c748 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.322407 [ 3131 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:50.324976 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:50.631518 [ 7933 ] {6b912684-691e-49f6-bb3f-32013b8f7c7a} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49622) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x00000000128bc4db 5. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000012835d95 6. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012835285 7. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:95: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bbd9 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 9. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 10. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 12. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 14. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 15. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 19. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 20. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 21. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 22. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.637607 [ 7933 ] {6b912684-691e-49f6-bb3f-32013b8f7c7a} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x00000000128bc4db 5. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000012835d95 6. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012835285 7. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:95: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bbd9 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 9. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 10. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 12. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 14. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 15. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 19. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 20. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 21. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 22. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.687965 [ 2929 ] {0d5353ab-ca5a-48f5-a953-c241672004e7} executeQuery: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49652) (comment: 02369_lost_part_intersecting_merges.sh) (in query: optimize table rmt1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957680 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.699941 [ 2929 ] {0d5353ab-ca5a-48f5-a953-c241672004e7} TCPHandler: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957680 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:50.833267 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:50.845702 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:50.962252 [ 3164 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:51.082872 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:51.198707 [ 2929 ] {e7c4dc92-08aa-49b3-a481-7c15fd504fe5} executeQuery: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49676) (comment: 02369_lost_part_intersecting_merges.sh) (in query: system sync replica rmt1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x00000000119453fb 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000001193c748 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:51.211939 [ 2929 ] {e7c4dc92-08aa-49b3-a481-7c15fd504fe5} TCPHandler: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x00000000119453fb 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x000000001193c748 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:51.324972 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:51.327239 [ 3238 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:51.835916 [ 3390 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:51.848476 [ 3231 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:51.964860 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:52.045709 [ 7933 ] {737aba20-f93e-4c92-a5b6-a66da45cfe7e} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49622) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x00000000128bc4db 5. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000012835d95 6. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012835285 7. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:95: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bbd9 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 9. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 10. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 12. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 14. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 15. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 19. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 20. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 21. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 22. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:14:52.048187 [ 7933 ] {737aba20-f93e-4c92-a5b6-a66da45cfe7e} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x00000000128bc4db 5. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:310: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x0000000012835d95 6. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:182: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012835285 7. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:95: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001283bbd9 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000001282a84f 9. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:183: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000128346dd 10. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000012952a11 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000012985d6f 12. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001298397f 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aaa7d2 14. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082cd3 15. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad1a9 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facade 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 19. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 20. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 21. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbe930 22. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb527d 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:14:52.329298 [ 3259 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:52.334407 [ 3043 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:52.411382 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:52.840112 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:52.844700 [ 2929 ] {dad0db2f-3a36-4bca-9257-372ed14ff750} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'rmt1' in scope SELECT 3, *, _part FROM rmt1 ORDER BY n ASC. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49686) (comment: 02369_lost_part_intersecting_merges.sh) (in query: select 3, *, _part from rmt1 order by 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:14:52.851985 [ 3072 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:52.863461 [ 2929 ] {dad0db2f-3a36-4bca-9257-372ed14ff750} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'rmt1' in scope SELECT 3, *, _part FROM rmt1 ORDER BY n 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:14:52.967723 [ 3411 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:53.332737 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:53.348175 [ 3314 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:53.652151 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:53.842553 [ 3424 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:53.863914 [ 2993 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:53.970401 [ 3345 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:54.337126 [ 3355 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:54.354212 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:54.586702 [ 2929 ] {df955295-5a96-49d8-bcda-4b35b14147d9} executeQuery: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49732) (comment: 02369_lost_part_intersecting_merges.sh) (in query: drop table rmt1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c19c 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>&) @ 0x0000000011571d54 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:54.622247 [ 2929 ] {df955295-5a96-49d8-bcda-4b35b14147d9} TCPHandler: Code: 60. DB::Exception: Table test_3.rmt1 does not exist. Maybe you meant test_3.rmt2?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c19c 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>&) @ 0x0000000011571d54 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:14:54.825326 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:54.845212 [ 2985 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:54.869164 [ 3412 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:54.972878 [ 3245 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:55.345989 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:55.356771 [ 3191 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:55.848113 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:55.872969 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:55.982855 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:56.093582 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:56.348762 [ 3250 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:56.359460 [ 3421 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:56.732053 [ 2929 ] {27aac45c-62ad-40c8-aace-f384bccc17cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=766). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49764) (comment: 02242_make_date.sql) (in query: select makeDate(2020, 08, 24);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:56.735818 [ 2929 ] {27aac45c-62ad-40c8-aace-f384bccc17cd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=766). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:14:56.851005 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:56.875403 [ 3479 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:56.888337 [ 7902 ] {9b05beb9-dd0f-42f0-80fd-118c1792e6df} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4): (while reading column x): (while reading from part /var/lib/clickhouse/store/4d7/4d7f3801-a3bc-41be-8448-1482ce3fe68d/20210601_2_2_0/ in table test_13.test_tz_hour (4d7f3801-a3bc-41be-8448-1482ce3fe68d) located on disk default of type local, from mark 0 with max_rows_to_read = 144): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49738) (comment: 02346_to_hour_monotonicity_fix.sql) (in query: select toHour(toTimeZone(t, 'UTC')) as toHour_UTC, toHour(toTimeZone(t, 'Asia/Jerusalem')) as toHour_Israel, count() from test_tz_hour where toHour_Israel = 8 group by toHour_UTC, toHour_Israel;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x00000000128f46f0 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 2025.09.25 21:14:56.988874 [ 3303 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:57.034917 [ 7902 ] {9b05beb9-dd0f-42f0-80fd-118c1792e6df} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4): (while reading column x): (while reading from part /var/lib/clickhouse/store/4d7/4d7f3801-a3bc-41be-8448-1482ce3fe68d/20210601_2_2_0/ in table test_13.test_tz_hour (4d7f3801-a3bc-41be-8448-1482ce3fe68d) located on disk default of type local, from mark 0 with max_rows_to_read = 144): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x00000000128f46f0 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) @ 0x0000000010d657f2 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 2025.09.25 21:14:57.318513 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:57.354533 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:57.365575 [ 3223 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:57.853917 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:57.878138 [ 3439 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:57.991765 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:58.356974 [ 3022 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:58.371790 [ 3357 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:58.536147 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:58.551868 [ 7615 ] {de8bb968-da29-4e8f-8d0b-10e3b380c677} executeQuery: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42978) (comment: 02494_query_cache_nondeterministic_functions.sql) (in query: SELECT count(now()) SETTINGS use_query_cache = true;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911a23 5. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:14:58.554597 [ 7615 ] {de8bb968-da29-4e8f-8d0b-10e3b380c677} TCPHandler: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911a23 5. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:14:58.585012 [ 7615 ] {1132eebe-c240-45ed-90fa-cbb59e7d11d7} executeQuery: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42978) (comment: 02494_query_cache_nondeterministic_functions.sql) (in query: SELECT count(now()) SETTINGS use_query_cache = true, query_cache_nondeterministic_function_handling = 'throw';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911a23 5. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:14:58.628228 [ 7615 ] {1132eebe-c240-45ed-90fa-cbb59e7d11d7} TCPHandler: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911a23 5. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:14:58.858139 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:58.888149 [ 2987 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:58.994444 [ 3352 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:59.275994 [ 7615 ] {a96d7786-efc1-44de-9a7c-68fb09f50d3a} 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.10508.altinitytest (altinity build)) (from [::1]:42978) (comment: 02494_query_cache_nondeterministic_functions.sql) (in query: SELECT count(now()) SETTINGS use_query_cache = true, query_cache_nondeterministic_function_handling = 'save';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:14:59.283974 [ 7615 ] {a96d7786-efc1-44de-9a7c-68fb09f50d3a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:14:59.367523 [ 3291 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:59.373990 [ 3083 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:59.757941 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:14:59.824999 [ 2929 ] {c8dc1485-3e15-4667-967b-527c2f6aea71} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42964) (comment: 01825_new_type_json_add_column.gen.sql) (in query: SELECT * FROM t_json_add_column ORDER BY id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:59.835253 [ 2929 ] {c8dc1485-3e15-4667-967b-527c2f6aea71} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:14:59.860652 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:59.890292 [ 3197 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:14:59.997017 [ 3275 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:00.371810 [ 3248 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:00.376778 [ 3237 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:00.862899 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:00.892371 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:00.924521 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:01.003651 [ 3270 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:01.374461 [ 3052 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:01.379378 [ 3232 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:01.864853 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:01.893888 [ 3335 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:01.915086 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:02.063369 [ 3154 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:02.376427 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:02.381104 [ 3388 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:02.818410 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:02.866493 [ 3056 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:02.895274 [ 3035 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:03.064898 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:03.378514 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:03.383226 [ 2965 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:03.747260 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:03.868560 [ 3417 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:03.896696 [ 3446 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:04.066600 [ 3141 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:04.392877 [ 3228 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:04.393581 [ 3334 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:04.632965 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:04.870302 [ 3064 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:04.898494 [ 3456 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.069052 [ 3160 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.250030 [ 7933 ] {ae99cc0d-5cfc-4285-8a74-580039e237ac} executeQuery: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43062) (comment: 01676_reinterpret_as.sql) (in query: SELECT reinterpret('123', 'FixedString(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/reinterpretAs.cpp:0: DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b52a52a 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:15:05.266305 [ 7933 ] {ae99cc0d-5cfc-4285-8a74-580039e237ac} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/reinterpretAs.cpp:0: DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b52a52a 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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:15:05.394479 [ 3118 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.395195 [ 3380 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.648920 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:05.813249 [ 2929 ] {e39880e8-cc71-4e7a-9fd1-d7205d603a4f} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43078) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, int const&, unsigned int&) @ 0x000000000934ff6b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000934f75a 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:15:05.823426 [ 2929 ] {e39880e8-cc71-4e7a-9fd1-d7205d603a4f} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, int const&, unsigned int&) @ 0x000000000934ff6b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000934f75a 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:15:05.872407 [ 3225 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.905600 [ 3135 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:05.920019 [ 2929 ] {3b97cdea-9381-4256-b975-9607276b02c7} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43078) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10000)) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, int const&, unsigned int&) @ 0x000000000934ff6b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000934f75a 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:15:05.930502 [ 2929 ] {3b97cdea-9381-4256-b975-9607276b02c7} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 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&, int const&, unsigned int&) @ 0x000000000934ff6b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000934f75a 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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:15:06.070824 [ 3427 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.396747 [ 3432 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.397191 [ 3151 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.535896 [ 3237 ] {} test_3.alter_compression_codec1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:15:06.537051 [ 4885 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Operation timeout (deadline of 10000 ms already expired) for path: /clickhouse/tables/test_3/test_00910/test_3alter_compression_codecs/s1/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&, String&&) @ 0x000000000c9687ab 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x00000000134b518e 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x00000000134ae071 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000134b3f87 7. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 9. ? @ 0x00007fd96814bac3 10. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.537138 [ 3389 ] {} test_13.forget_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:15:06.538569 [ 3052 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:15:06.548503 [ 3268 ] {} test_3.alter_compression_codec2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:15:06.548601 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.555405 [ 3299 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.561372 [ 2991 ] {} test_3.alter_compression_codec2 (7452f638-550b-48e2-8721-ae1bca09810f): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000134b2afc 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345e340 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345deb5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eab2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345e9cb 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000129ff8c5 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x00000000123b2d78 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.631695 [ 3252 ] {} test_3.alter_compression_codec1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/test_3/test_00910/test_3alter_compression_codecs/s1/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001345eb11 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001345e66f 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x00000000129d758a 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000129d3120 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000129cf833 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000129ce89a 11. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 13. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.747652 [ 3061 ] {} test_3.alter_compression_codec2 (7452f638-550b-48e2-8721-ae1bca09810f): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000001348857b 3. /build/src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afd42 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000134b0c65 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013461f5c 6. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000013461b07 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000013462659 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 9. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000129fb806 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000123b2a62 12. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.797207 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:06.874748 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:06.907800 [ 3210 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.072889 [ 3481 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.399085 [ 3409 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.399832 [ 3019 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.551058 [ 3378 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.866638 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:07.876892 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:07.909817 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.076563 [ 3086 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.401504 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.401978 [ 3105 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.555255 [ 3395 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.885989 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.911463 [ 3085 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:08.926986 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:09.081210 [ 3133 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:09.096576 [ 5600 ] {3474e9a4-a56e-4452-b3aa-b4f627c99b45} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36124) (comment: 01855_jit_comparison_constant_result.sql) (in query: CREATE TABLE test_table (`a` UInt64) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 24122, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.6170623302459717, 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 = 319043598, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 31186197, merge_max_block_size = 1608, old_parts_lifetime = 141., 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 = 1, index_granularity_bytes = 3467320, concurrent_part_removal_threshold = 40, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 47979, primary_key_compress_block_size = 56520), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:09.123165 [ 5600 ] {3474e9a4-a56e-4452-b3aa-b4f627c99b45} TCPHandler: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:09.406496 [ 3191 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:09.406645 [ 3489 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:09.557100 [ 3034 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:09.887695 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:09.905196 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:09.913677 [ 3479 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.093077 [ 3039 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.409096 [ 3157 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.409592 [ 3060 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.488959 [ 4665 ] {b6a77060-03de-4ba0-a2c0-85d4d5f5ecb0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/601/60192ec9-51d2-424c-855e-2aa3a68b8b91/20200104_4_4_0/ in table test_13.merge_tree (60192ec9-51d2-424c-855e-2aa3a68b8b91) 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.10508.altinitytest (altinity build)) (from [::1]:36130) (comment: 01073_bad_alter_partition.sql) (in query: SELECT 1, * FROM merge_tree ORDER BY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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&) @ 0x0000000010ba4c8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ba9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2e37c 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:15:10.527474 [ 4665 ] {b6a77060-03de-4ba0-a2c0-85d4d5f5ecb0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/601/60192ec9-51d2-424c-855e-2aa3a68b8b91/20200104_4_4_0/ in table test_13.merge_tree (60192ec9-51d2-424c-855e-2aa3a68b8b91) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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&) @ 0x0000000010ba4c8b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ba9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2e37c 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 @ 0x0000000010cd58d9 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>>>*) @ 0x00000000128d9d49 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>>&) @ 0x00000000128ef7c0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e287f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb5fc 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9877 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907860 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7a2f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x00000000129047d7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 2025.09.25 21:15:10.559458 [ 3279 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.890063 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:10.916435 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.067884 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:11.095858 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.411948 [ 3371 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.415083 [ 3024 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.570407 [ 3126 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.892879 [ 3028 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:11.918918 [ 3465 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.098667 [ 3180 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.177179 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:12.417056 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.420137 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.577251 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.582970 [ 8473 ] {13a8ac14-f9af-421f-9375-f196a0b4d4fe} executeQuery: Code: 57. DB::Exception: Table test_srkp9cht.test_02240_storage_policy already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36216) (comment: 02240_system_filesystem_cache_table.sh) (in query: CREATE TABLE test_02240_storage_policy (key UInt32, value String) Engine=MergeTree() ORDER BY key SETTINGS storage_policy='azure_cache', min_bytes_for_wide_part = 1000000, compress_marks=false, compress_primary_key=false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:12.586780 [ 8473 ] {13a8ac14-f9af-421f-9375-f196a0b4d4fe} TCPHandler: Code: 57. DB::Exception: Table test_srkp9cht.test_02240_storage_policy 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:12.898500 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:12.921872 [ 3143 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.101222 [ 3134 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.363650 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:13.419474 [ 3221 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.426213 [ 3057 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.579517 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.901656 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.924098 [ 3367 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:13.977982 [ 4665 ] {58908ef6-cc24-4007-a034-a6e466d0bd91} executeQuery: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36258) (comment: 02688_long_aggregate_function_names.sql) (in query: SELECT minOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNull(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/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 const&) @ 0x0000000007afb10b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:323: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x00000000104bd782 5. /build/src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x0000000011080a79 6. /build/src/Analyzer/Resolve/IdentifierResolveScope.cpp:107: DB::IdentifierResolveScope::pushExpressionNode(std::shared_ptr const&) @ 0x000000001107f01a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038c5f 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:15:13.993581 [ 4665 ] {58908ef6-cc24-4007-a034-a6e466d0bd91} TCPHandler: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/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 const&) @ 0x0000000007afb10b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:323: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x00000000104bd782 5. /build/src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x0000000011080a79 6. /build/src/Analyzer/Resolve/IdentifierResolveScope.cpp:107: DB::IdentifierResolveScope::pushExpressionNode(std::shared_ptr const&) @ 0x000000001107f01a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038c5f 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 26. ? @ 0x00007fd96814bac3 27. ? @ 0x00007fd9681dd850 2025.09.25 21:15:14.103584 [ 3326 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:14.425050 [ 3444 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:14.428594 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:14.542710 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:14.584748 [ 3400 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:14.904297 [ 3304 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:14.926448 [ 3319 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.109361 [ 3107 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.427832 [ 3402 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.431078 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.587119 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.659851 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:15.907630 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:15.931483 [ 3059 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.111926 [ 3316 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.432635 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.433772 [ 3223 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.591568 [ 3290 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.798532 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:16.910366 [ 3445 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:16.933775 [ 3100 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.114541 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.435374 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.436220 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.594360 [ 3311 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.912895 [ 3003 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:17.936441 [ 3278 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.009677 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:18.117636 [ 3338 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.438206 [ 3292 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.438653 [ 3139 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.593183 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1aef7ea7-cbf0-4db2-93e7-d853aa133566::202509_1_99_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.597154 [ 3041 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.825739 [ 4665 ] {6d1f2d50-3fa5-42e2-a302-92f6797ce776} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53020) (comment: 03215_key_condition_bug.sql) (in query: CREATE TABLE t (`x` Int8) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 33397, 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 = 0, compact_parts_max_bytes_to_buffer = 428366711, compact_parts_max_granules_to_buffer = 122, compact_parts_merge_max_bytes_to_prefetch_part = 4086998, merge_max_block_size = 12943, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 797639, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10544099907, index_granularity_bytes = 23153342, concurrent_part_removal_threshold = 59, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 25756, primary_key_compress_block_size = 52995), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:18.849353 [ 4665 ] {6d1f2d50-3fa5-42e2-a302-92f6797ce776} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:18.915668 [ 3018 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:18.939355 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.198078 [ 3253 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.258637 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:19.440964 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.445725 [ 2969 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.599862 [ 3283 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.917602 [ 4665 ] {dd74c226-1488-4704-8fa4-02f84e87ee28} executeQuery: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53046) (comment: 01463_resample_overflow.sql) (in query: select groupArrayResample(-9223372036854775808, 9223372036854775807, 9223372036854775807)(number, toInt64(number)) FROM numbers(7);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Combinators/AggregateFunctionResample.h:0: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025d1c0 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025cd2a 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001025aa5d 7. /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 @ 0x00000000104bc717 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:15:19.917863 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:19.920972 [ 4665 ] {dd74c226-1488-4704-8fa4-02f84e87ee28} TCPHandler: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/Combinators/AggregateFunctionResample.h:0: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025d1c0 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000001025cd2a 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001025aa5d 7. /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 @ 0x00000000104bc717 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bb8d4 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f421 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:15:19.941745 [ 3451 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.201044 [ 3203 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.414476 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:20.443412 [ 3048 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.451054 [ 3093 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.602490 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.920026 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:20.943623 [ 3130 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.121558 [ 4665 ] {7f01db7d-e4e8-48c2-b8a3-d565e62d2aec} executeQuery: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_function`. (UNKNOWN_FUNCTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53058) (comment: 02101_sql_user_defined_functions_drop_if_exists.sql) (in query: DROP FUNCTION 02101_test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x00000000132421b9 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x0000000013234000 6. /build/src/QueryPipeline/BlockIO.h:14: DB::InterpreterDropFunctionQuery::execute() @ 0x000000001197b661 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:21.131195 [ 4665 ] {7f01db7d-e4e8-48c2-b8a3-d565e62d2aec} TCPHandler: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x00000000132421b9 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x0000000013234000 6. /build/src/QueryPipeline/BlockIO.h:14: DB::InterpreterDropFunctionQuery::execute() @ 0x000000001197b661 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:15:21.215982 [ 3317 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.370855 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:21.449084 [ 3042 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.453702 [ 3421 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.609546 [ 3106 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.922609 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:21.945617 [ 2997 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.301879 [ 3103 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.399599 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:22.459062 [ 3068 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.459368 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.612025 [ 3400 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.925454 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:22.949339 [ 3374 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.304418 [ 3209 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.463318 [ 3173 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.463626 [ 3315 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.576727 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:23.614541 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.928227 [ 3047 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:23.951657 [ 3262 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.102910 [ 4665 ] {c195d8e6-0fea-4d5b-b1ea-9f3daf6c4a3f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53126) (comment: 00955_test_final_mark_use.sh) (in query: SELECT COUNT(*) FROM mt_with_pk WHERE x > toDateTime('2018-10-01 23:57:57') 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:15:24.115377 [ 4665 ] {c195d8e6-0fea-4d5b-b1ea-9f3daf6c4a3f} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:15:24.329288 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.550505 [ 3448 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.550669 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.618130 [ 3264 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.820730 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:24.933746 [ 3222 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:24.958811 [ 3320 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.331914 [ 3229 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.556230 [ 3061 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.556655 [ 2991 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.620854 [ 3373 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.940377 [ 3055 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:25.961389 [ 3164 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.096543 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:26.334672 [ 3239 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.572596 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.573763 [ 3117 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.629373 [ 3311 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.943996 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:26.963961 [ 3100 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.226893 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:27.340390 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.575510 [ 2982 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.576365 [ 3102 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.632130 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.946858 [ 3218 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:27.965526 [ 3483 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.226803 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:28.322351 [ 4665 ] {9251ace2-ee38-4cca-99be-6f6bc53e56e3} 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.10508.altinitytest (altinity build)) (from [::1]:53182) (comment: 02950_reading_array_tuple_subcolumns.sql) (in query: SELECT t.b, t.b.c FROM test ORDER BY id 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:15:28.346617 [ 4665 ] {9251ace2-ee38-4cca-99be-6f6bc53e56e3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:15:28.346859 [ 3030 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.578377 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.579654 [ 3084 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.635018 [ 2989 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.949239 [ 3217 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:28.969030 [ 3273 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.115541 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:29.349885 [ 3165 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.581032 [ 3488 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.585840 [ 3227 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.640555 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.951356 [ 3274 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:29.970968 [ 3184 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.196778 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:30.352382 [ 3340 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.586470 [ 3122 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.588442 [ 3020 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.649398 [ 3408 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.953765 [ 3275 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:30.973319 [ 3296 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.261296 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:31.354574 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.589844 [ 3337 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.591467 [ 3146 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.652709 [ 3271 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.956436 [ 3137 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:31.982626 [ 3178 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:32.340129 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:32.357052 [ 3043 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:32.670424 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:32.670603 [ 3174 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:32.670715 [ 3459 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:32.958683 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.000638 [ 3053 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.359876 [ 3338 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.512109 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:33.672829 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.673248 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.674028 [ 3240 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:33.960456 [ 3096 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.002186 [ 3435 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.362314 [ 3058 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.674812 [ 3142 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.675575 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.676547 [ 3009 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:34.686073 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:34.961957 [ 3286 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.007982 [ 3116 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.365154 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.677594 [ 3045 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.680584 [ 3301 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.692245 [ 3293 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:35.837452 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:35.964615 [ 3263 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.013818 [ 3393 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.367881 [ 3200 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.681117 [ 3189 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.683555 [ 3430 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.695008 [ 3167 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.968402 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:36.995038 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:37.016603 [ 3066 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:37.370447 [ 3344 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:37.685647 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:37.685797 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:37.697661 [ 2976 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:37.970977 [ 3269 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.018970 [ 3211 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.201920 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:38.373214 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.688080 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.688149 [ 3048 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.703187 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:38.973525 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.021866 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.376163 [ 3191 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.386371 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:39.690438 [ 3025 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.690830 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.708198 [ 3210 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:39.976388 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.024292 [ 3221 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.378777 [ 3018 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.692501 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:40.693045 [ 3429 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.693487 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.717126 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:40.978839 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:41.026737 [ 3333 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:41.388213 [ 3416 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:41.570760 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:41.694934 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:41.695193 [ 3452 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:41.719088 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.035883 [ 3469 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.036037 [ 3381 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.390372 [ 3334 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.697489 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.700907 [ 3282 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.732184 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:42.814772 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:43.038276 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.040567 [ 3322 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.393198 [ 3118 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.702218 [ 3277 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.702958 [ 3124 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.737322 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:43.851578 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:44.040797 [ 3328 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.042552 [ 3137 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.402826 [ 3380 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.704685 [ 3056 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.708484 [ 3468 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.747034 [ 3128 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:44.825414 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:45.042890 [ 3178 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.046417 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.405134 [ 3151 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.706811 [ 3451 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.710382 [ 3035 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.752036 [ 3091 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:45.809453 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:46.045137 [ 3478 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:46.048409 [ 3027 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:46.407471 [ 3019 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:46.708799 [ 3240 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:46.712210 [ 3267 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:46.712684 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:46.754310 [ 3189 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.046974 [ 3160 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.055017 [ 3370 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.409293 [ 3392 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.678604 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:47.710800 [ 3142 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.717912 [ 3224 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:47.758542 [ 3430 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.052901 [ 3205 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.060436 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.415927 [ 3194 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.545010 [ 2929 ] {e648f3a9-3d5d-40e4-8108-b471f0fb798c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as Date), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.548923 [ 2929 ] {e648f3a9-3d5d-40e4-8108-b471f0fb798c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.630523 [ 2929 ] {a022b935-c189-432d-8ae8-ee4d62c7bb61} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as Date), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.639568 [ 2929 ] {a022b935-c189-432d-8ae8-ee4d62c7bb61} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.699211 [ 2929 ] {f40d55c4-dcfa-44a8-9ce9-c89363d5f355} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as Date32), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.702287 [ 2929 ] {f40d55c4-dcfa-44a8-9ce9-c89363d5f355} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.712953 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.719997 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.761184 [ 3132 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:48.761566 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.783813 [ 2929 ] {47327b3c-02c9-4941-8e81-8e5487cb4b64} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as Date32), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.786788 [ 2929 ] {47327b3c-02c9-4941-8e81-8e5487cb4b64} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.816869 [ 2929 ] {8c05e9db-494b-4c8f-a0d5-2c0d644bfb47} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as DateTime), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.818673 [ 2929 ] {8c05e9db-494b-4c8f-a0d5-2c0d644bfb47} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.838961 [ 2929 ] {00d51348-3922-43b1-bbb1-768070603746} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as DateTime), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.842087 [ 2929 ] {00d51348-3922-43b1-bbb1-768070603746} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.871357 [ 2929 ] {b51460aa-9a56-41c3-84da-3e6c61d95f05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(1980 as DateTime64), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.872680 [ 2929 ] {b51460aa-9a56-41c3-84da-3e6c61d95f05} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.899832 [ 2929 ] {13975352-9d2c-4e92-99fe-a18ace86a104} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(cast(-1980 as DateTime64), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.901603 [ 2929 ] {13975352-9d2c-4e92-99fe-a18ace86a104} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.990682 [ 2929 ] {b3acb0a3-98cb-4019-a38f-08984d90e8a8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('1980', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:48.993661 [ 2929 ] {b3acb0a3-98cb-4019-a38f-08984d90e8a8} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.055482 [ 3039 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.062921 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.119999 [ 2929 ] {528edfae-0c42-4db1-b436-f41c85a22fcb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('-1980', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.122387 [ 2929 ] {528edfae-0c42-4db1-b436-f41c85a22fcb} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.160388 [ 2929 ] {43dc87c1-40b9-4994-a574-ce1d89c6cf6d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32('aa', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.163167 [ 2929 ] {43dc87c1-40b9-4994-a574-ce1d89c6cf6d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.200333 [ 2929 ] {18754fba-720e-494d-87e4-0db4b89ab83a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44090) (comment: 02243_make_date32_mysql.sql) (in query: select makeDate32(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.208034 [ 2929 ] {18754fba-720e-494d-87e4-0db4b89ab83a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bc109 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&) @ 0x00000000110501ab 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 30. ? @ 0x00007fd96814bac3 31. ? @ 0x00007fd9681dd850 2025.09.25 21:15:49.422717 [ 3318 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.715092 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.721854 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.763566 [ 2964 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:49.767072 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:50.061142 [ 3077 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.064808 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.425428 [ 3489 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.717582 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.724002 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.768126 [ 2976 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:50.825098 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:51.066691 [ 3435 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.066964 [ 3096 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.430910 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.720033 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.725913 [ 3048 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.770202 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:51.861708 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:52.077362 [ 3423 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.080187 [ 3404 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.435654 [ 3221 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.731337 [ 3212 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.731073 [ 3368 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.776204 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:52.947466 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:53.080006 [ 3079 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:53.083007 [ 3276 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:53.438034 [ 3042 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:53.733934 [ 3247 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:53.744335 [ 3072 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:53.778418 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.081748 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.084923 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.089155 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:54.442092 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.739178 [ 3135 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.746589 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:54.748325 [ 7937 ] {cae9ffe9-807d-4c49-8f98-835f6787ba31} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): while reading column value1 at /var/lib/clickhouse/store/7be/7be4b556-29e0-48d3-a5a6-e8aa128f0f31/: While executing Log. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:47550) (comment: 01894_jit_aggregation_function_max_long.sql) (in query: SELECT id, min(value1), min(value2) FROM test_table_float_values 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3cd0 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3753f 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 @ 0x0000000010cd58d9 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>>>&) @ 0x00000000124f61ae 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 2025.09.25 21:15:54.760304 [ 7937 ] {cae9ffe9-807d-4c49-8f98-835f6787ba31} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): while reading column value1 at /var/lib/clickhouse/store/7be/7be4b556-29e0-48d3-a5a6-e8aa128f0f31/: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000104d765a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d744f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d6670 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce2a2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce58b 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) @ 0x0000000010ba3f8b 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3cd0 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3753f 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 @ 0x0000000010cd58d9 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>>>&) @ 0x00000000124f61ae 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f56ac 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 26. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 2025.09.25 21:15:54.780633 [ 3085 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.084346 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.087681 [ 2968 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.288602 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:55.447477 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.741801 [ 2987 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.749306 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:55.787501 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.086852 [ 3003 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.092973 [ 3278 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.450466 [ 3173 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.510621 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:56.744284 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.751750 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:56.793111 [ 3411 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.090920 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.095424 [ 3309 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.523490 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.742107 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:57.746474 [ 3297 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.757449 [ 3273 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:57.795721 [ 3183 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.057728 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:58.093658 [ 3219 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.170884 [ 2992 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.526232 [ 3331 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.752900 [ 3382 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.760059 [ 3281 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.798178 [ 3084 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:58.978694 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:15:59.096396 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:59.239888 [ 3174 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:59.528946 [ 3440 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:59.755461 [ 3325 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:59.762338 [ 3430 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:15:59.801089 [ 3093 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.098630 [ 3438 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.109279 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:00.248749 [ 3065 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.532084 [ 3230 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.760092 [ 3255 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.769774 [ 2970 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:00.803203 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.103411 [ 3481 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.152564 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:01.250896 [ 3406 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.534374 [ 3248 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.762091 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.771992 [ 3198 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.805825 [ 3415 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:01.845008 [ 7902 ] {b1b02f9b-9f9c-4ed8-8358-0cb1af9fd4a5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40490) (comment: 00331_final_and_prewhere.sql) (in query: SELECT * FROM replace FINAL WHERE Version = 0 ORDER BY Id, Version;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:16:01.865098 [ 7902 ] {b1b02f9b-9f9c-4ed8-8358-0cb1af9fd4a5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5930 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.106197 [ 3171 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:02.131842 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.253144 [ 3405 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:02.467930 [ 2928 ] {5c9c1b9b-968b-4ae0-a0cc-741f5b90e0dd} executeQuery: Code: 57. DB::Exception: Table test_3.t_index already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40500) (comment: 02319_sql_standard_create_drop_index.sql) (in query: create table t_index(a int, b String) engine=ReplicatedMergeTree('/test/2319/{database}', '1') order by 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.473894 [ 2928 ] {5c9c1b9b-968b-4ae0-a0cc-741f5b90e0dd} TCPHandler: Code: 57. DB::Exception: Table test_3.t_index 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.536893 [ 3389 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:02.609509 [ 7902 ] {6d3e0285-e561-4c07-ae62-f13b6209ca8e} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40532) (comment: 02989_variant_comparison.sql) (in query: create table test (v1 Variant(String, UInt64, Array(UInt32)), v2 Variant(String, UInt64, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.628086 [ 7902 ] {6d3e0285-e561-4c07-ae62-f13b6209ca8e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:02.765843 [ 3260 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:02.778365 [ 2964 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:02.811669 [ 3365 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.109149 [ 3039 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.255534 [ 3082 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.309631 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:03.539970 [ 3331 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.573910 [ 7902 ] {0b10a535-ab86-43b1-a4b7-771b471c0c56} executeQuery: Code: 57. DB::Exception: Table test_13.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40546) (comment: 03263_analyzer_materialized_view_cte_nested.sql) (in query: CREATE TABLE test_table ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 5503, min_bytes_for_wide_part = 422754824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 48, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 493704766, compact_parts_max_granules_to_buffer = 194, compact_parts_merge_max_bytes_to_prefetch_part = 21947619, merge_max_block_size = 14465, old_parts_lifetime = 130., prefer_fetch_merged_part_size_threshold = 125293083, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 599552, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 17478, primary_key_compress_block_size = 37663 AS SELECT 1 AS col1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:03.595320 [ 7902 ] {0b10a535-ab86-43b1-a4b7-771b471c0c56} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:03.768525 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.780957 [ 3470 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:03.814351 [ 2988 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.111885 [ 3306 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.258135 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.487794 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:04.548143 [ 3336 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.771797 [ 2974 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.784993 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:04.820822 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.114626 [ 3136 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.260371 [ 3294 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.551048 [ 3148 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.779179 [ 3127 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.790630 [ 3241 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:05.823968 [ 2999 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.117350 [ 3350 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.179146 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:06.262635 [ 3425 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.308217 [ 8473 ] {1afdbbf6-41b5-48c0-93f2-047e39508d91} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40584) (comment: 02243_drop_user_grant_race.sh) (in query: CREATE TABLE test (n 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:06.337454 [ 8473 ] {1afdbbf6-41b5-48c0-93f2-047e39508d91} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:06.553918 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.783998 [ 2976 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.803956 [ 3193 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:06.826526 [ 3436 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.127805 [ 3464 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.265068 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.558978 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.599615 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:07.789644 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.806096 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:07.832160 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.130502 [ 3391 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.268373 [ 3182 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.561743 [ 3179 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.765100 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:08.792311 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.808513 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:08.837930 [ 3064 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.208805 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.270458 [ 3190 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.650573 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.705730 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:09.797029 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.811512 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:09.840101 [ 3080 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.210850 [ 3307 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.272347 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.620567 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:10.652958 [ 3271 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.799054 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.813828 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:10.842286 [ 3121 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.212666 [ 3443 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.274220 [ 3477 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.561418 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:11.654831 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.806104 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.815669 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:11.846729 [ 3397 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.214842 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.276537 [ 3037 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.662784 [ 3413 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.690134 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:12.809463 [ 3479 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.817210 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:12.849233 [ 2987 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.169789 [ 4665 ] {4563ae08-4222-410a-aae5-fb48a4215724} executeQuery: Code: 43. DB::Exception: Function untuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43474) (comment: 03142_untuple_crash.sql) (in query: SELECT untuple(x -> 0) -- { serverError 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:3086: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053761 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:16:13.171238 [ 4665 ] {4563ae08-4222-410a-aae5-fb48a4215724} TCPHandler: Code: 43. DB::Exception: Function untuple can't have lambda-expressions as arguments. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:3086: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053761 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:16:13.218302 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.362708 [ 3021 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.664920 [ 3358 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.763333 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:13.811450 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.819303 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:13.851594 [ 3319 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.221224 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.365789 [ 3199 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.667488 [ 3166 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.814261 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.821600 [ 3138 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:14.854367 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.017413 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.070600 [ 4665 ] {9112562f-c1a1-48d0-8ca6-98bbe9438ae0} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43532) (comment: 02374_analyzer_array_join.sql) (in query: CREATE TABLE test_table ( id UInt64, value String, value_array Array(UInt64), value_array_array Array(Array(UInt64)) ) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.072156 [ 5600 ] {75f57ef2-3770-445f-a6f3-45e24176412b} 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.10508.altinitytest (altinity build)) (from [::1]:43524) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.073360 [ 4665 ] {9112562f-c1a1-48d0-8ca6-98bbe9438ae0} TCPHandler: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.075026 [ 5600 ] {75f57ef2-3770-445f-a6f3-45e24176412b} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.144934 [ 5600 ] {72ee1018-af19-42e0-8935-f84910daceba} 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.10508.altinitytest (altinity build)) (from [::1]:43524) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.149427 [ 5600 ] {72ee1018-af19-42e0-8935-f84910daceba} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.223988 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.368362 [ 3058 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.397711 [ 5600 ] {62494467-8661-464c-9299-7c83c90c48c7} 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.10508.altinitytest (altinity build)) (from [::1]:43524) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.409687 [ 5600 ] {62494467-8661-464c-9299-7c83c90c48c7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.580675 [ 5600 ] {116fec76-60e7-4fc3-a5e6-7b1519102046} 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.10508.altinitytest (altinity build)) (from [::1]:43524) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.591281 [ 5600 ] {116fec76-60e7-4fc3-a5e6-7b1519102046} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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&) @ 0x00000000110501ab 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:16:15.673766 [ 3013 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.792192 [ 5600 ] {59ca55bb-83f7-4bf4-8cd8-f5df7e1dd63d} 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.10508.altinitytest (altinity build)) (from [::1]:43524) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:16:15.808056 [ 5600 ] {59ca55bb-83f7-4bf4-8cd8-f5df7e1dd63d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x0000000011050d10 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 2025.09.25 21:16:15.816634 [ 3217 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.824081 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:15.954503 [ 3297 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.133190 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:16.228429 [ 3361 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.371652 [ 3200 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.676343 [ 3142 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.836974 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.837640 [ 3314 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:16.956927 [ 3207 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.214690 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.231127 [ 3223 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.373753 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.434092 [ 7898 ] {a1c7f299-e0bc-4b59-a4a8-9f8ac7c3b48d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58550) (comment: 02240_system_filesystem_cache_table.sh) (in query: DROP DATABASE IF EXISTS test_srkp9cht ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.437504 [ 7898 ] {a1c7f299-e0bc-4b59-a4a8-9f8ac7c3b48d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.468766 [ 2929 ] {06ccddb3-8ff7-4027-a589-0a0f29796725} executeQuery: Code: 57. DB::Exception: Table test_naaweso6.test_02312 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56292) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (in query: create table test_02312 (x Tuple(a UInt32, b UInt32)) engine=File(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.476139 [ 2929 ] {06ccddb3-8ff7-4027-a589-0a0f29796725} TCPHandler: Code: 57. DB::Exception: Table test_naaweso6.test_02312 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.607855 [ 7898 ] {1bbaed37-607f-4d84-919d-c78a43b14648} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58562) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (in query: DROP DATABASE IF EXISTS test_naaweso6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.611579 [ 7898 ] {1bbaed37-607f-4d84-919d-c78a43b14648} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.678628 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.763914 [ 2929 ] {50b9a650-83dd-4ae1-8654-4548a73baecd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58570) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (in query: DROP DATABASE IF EXISTS test_naaweso6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:17.797595 [ 2929 ] {50b9a650-83dd-4ae1-8654-4548a73baecd} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.839800 [ 3139 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.843184 [ 3441 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:17.959179 [ 3087 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.236360 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.273241 [ 7937 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:18.376202 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.684417 [ 3099 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.843141 [ 3081 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.845446 [ 3081 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:18.961408 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.238764 [ 3418 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.300579 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:19.378390 [ 3344 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.508611 [ 2948 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012515731 9. /build/src/Storages/StorageBuffer.cpp:1088: DB::StorageBuffer::backgroundFlush() @ 0x0000000012518c92 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.686724 [ 3017 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.845214 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.847742 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:19.963986 [ 3163 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.244252 [ 3065 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.380784 [ 3355 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.461603 [ 7898 ] {b5082a98-576e-42c1-ab22-6792921e23df} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'nonexistentsomething' in scope SELECT nonexistentsomething. (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56308) (comment: 01083_expressions_in_engine_arguments.sql) (in query: -- The following line is needed just to disable checking stderr for emptiness SELECT nonexistentsomething;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:16:20.462879 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:20.463981 [ 7898 ] {b5082a98-576e-42c1-ab22-6792921e23df} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'nonexistentsomething' in scope SELECT nonexistentsomething. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/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&&) @ 0x0000000011066219 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103aa31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:16:20.689185 [ 3475 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.847734 [ 3436 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.850088 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:20.983929 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.247035 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.383006 [ 3115 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.592450 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:21.619901 [ 7902 ] {a4b0f303-fc96-4ee4-b11d-f50986a0031e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58598) (comment: 01710_projection_query_plan_optimization_misc.sql) (in query: DROP DATABASE IF EXISTS test_3s0139b9 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:21.623926 [ 7902 ] {a4b0f303-fc96-4ee4-b11d-f50986a0031e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.686446 [ 2929 ] {f76e62a4-275d-495d-8eca-b9a5542ac429} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58600) (comment: 01710_projection_query_plan_optimization_misc.sql) (in query: DROP DATABASE IF EXISTS test_3s0139b9 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:21.690337 [ 2929 ] {f76e62a4-275d-495d-8eca-b9a5542ac429} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.692218 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.809146 [ 7933 ] {5c3f6c3e-76eb-4aa7-98b6-9b2f400afd93} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56320) (comment: 02364_multiSearch_function_family.sql) (in query: select [1] = multiSearchAllPositions(materialize('abcdefgh'), ['abcdef']);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:21.813716 [ 7933 ] {5c3f6c3e-76eb-4aa7-98b6-9b2f400afd93} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:21.852686 [ 3398 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.853228 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:21.987467 [ 3031 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.250269 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.385462 [ 3416 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.694682 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.752462 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:22.855528 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.855804 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:22.990288 [ 3303 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.253523 [ 3406 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.387979 [ 3228 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.697175 [ 3282 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.858215 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.858644 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:23.860736 [ 3243 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:23.992694 [ 3385 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.244841 [ 3206 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011182184 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182677 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.255911 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.392521 [ 3118 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.701847 [ 3277 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.860331 [ 3051 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.866309 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:24.878191 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:24.994749 [ 3297 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.258210 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.394584 [ 3380 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.704785 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.862727 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.868624 [ 3070 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:25.985368 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:25.996932 [ 3114 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:26.260324 [ 3453 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:26.396455 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:26.707575 [ 3434 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:26.868679 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:26.870765 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.015879 [ 3184 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.016813 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:27.262213 [ 3294 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.398237 [ 3377 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.709783 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.870753 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.873250 [ 2985 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:27.949631 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:28.020592 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.268526 [ 3069 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.400565 [ 3302 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.606553 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.09.25 21:16:28.712345 [ 3487 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.739927 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} Cluster: Code: 198. DB::NetException: Not found address of host: localhosx. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:855: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011551f05 14. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.873732 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:28.875627 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.023571 [ 3438 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.126797 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:29.271579 [ 3182 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.403541 [ 3105 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.714974 [ 3240 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.829073 [ 7933 ] {3f3bdebf-0eea-401b-98da-59660bbbb597} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44886) (comment: 02155_binary_op_between_float_and_decimal.sql) (in query: CREATE TABLE t(d1 Decimal32(5), d2 Decimal64(10), d3 Decimal128(20), d4 Decimal256(40), f1 Float32, f2 Float64) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:29.845813 [ 7933 ] {3f3bdebf-0eea-401b-98da-59660bbbb597} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:16:29.974552 [ 3234 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:29.974696 [ 3449 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.026169 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.275993 [ 3078 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.332849 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:30.408765 [ 3191 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.722460 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.987504 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:30.987932 [ 3197 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.028825 [ 3171 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.280776 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.414076 [ 3057 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.620900 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:31.724255 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.989871 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:31.993678 [ 3172 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.034686 [ 3053 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.283667 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.416045 [ 3250 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.616909 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:32.725815 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.991713 [ 3482 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:32.995663 [ 3014 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:33.037562 [ 3286 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:33.285593 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:33.417641 [ 3040 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:33.541158 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:33.727745 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:33.907483 [ 5326 ] {43d2ea00-da7d-4a98-a820-55209f935bf2} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44922) (comment: 01785_dictionary_element_count.sql) (in query: DROP DICTIONARY 01785_db.simple_key_hashed_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:33.911066 [ 5326 ] {43d2ea00-da7d-4a98-a820-55209f935bf2} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:33.996259 [ 3015 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.002059 [ 3229 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.039477 [ 3431 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.229738 [ 7933 ] {ab679c5d-3efe-4b4f-8c39-7833e9bf954c} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44990) (comment: 02731_auto_convert_dictionary_layout_to_complex_by_complex_keys.sql) (in query: DROP DICTIONARY dict_flat_simple;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:34.242247 [ 7933 ] {ab679c5d-3efe-4b4f-8c39-7833e9bf954c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:16:34.287385 [ 3309 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.419420 [ 3292 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.462510 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:34.729747 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:34.998627 [ 3291 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.004452 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.045361 [ 3420 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.289411 [ 3181 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.421257 [ 3237 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.508897 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:35.732002 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:35.927892 [ 5326 ] {0f7c3ff6-37ae-4d24-b2e4-03a7015fa4b9} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45040) (comment: 02985_minmax_index_aggregate_function.sql) (in query: CREATE TABLE t_index_agg_func (`id` UInt64, `v` AggregateFunction(avg, UInt64), INDEX idx_v v TYPE minmax GRANULARITY 1) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS index_granularity = 4, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.41936853528022766, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 428015297, compact_parts_max_bytes_to_buffer = 504959982, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 13986385, merge_max_block_size = 10709, old_parts_lifetime = 331., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 15653574, concurrent_part_removal_threshold = 9, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 86864, primary_key_compress_block_size = 61703), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Storages/MergeTree/MergeTreeIndexMinMax.cpp:0: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000012879d9f 5. /build/contrib/llvm-project/libcxx/include/unordered_set:785: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277daa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000012778710 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775dc 8. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 9. /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>&&) @ 0x0000000012a754d0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 11. /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 @ 0x00000000122534a7 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:16:35.934959 [ 5326 ] {0f7c3ff6-37ae-4d24-b2e4-03a7015fa4b9} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Storages/MergeTree/MergeTreeIndexMinMax.cpp:0: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000012879d9f 5. /build/contrib/llvm-project/libcxx/include/unordered_set:785: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277daa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:722: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000012778710 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000127775dc 8. /build/src/Storages/StorageMergeTree.cpp:96: 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>) @ 0x0000000012a7578a 9. /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>&&) @ 0x0000000012a754d0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 11. /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 @ 0x00000000122534a7 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d837 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.005911 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.006929 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.023494 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.047766 [ 2982 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.305603 [ 3311 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.426075 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.451365 [ 5326 ] {ccdee93e-554c-4d33-b00f-f16376804a7d} executeQuery: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45040) (comment: 02985_minmax_index_aggregate_function.sql) (in query: ALTER TABLE t_index_agg_func ADD INDEX idx_v v TYPE minmax GRANULARITY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Storages/MergeTree/MergeTreeIndexMinMax.cpp:0: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000012879d9f 5. /build/contrib/llvm-project/libcxx/include/unordered_set:785: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277daa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.455942 [ 5326 ] {ccdee93e-554c-4d33-b00f-f16376804a7d} TCPHandler: Code: 36. DB::Exception: Data type of argument for minmax index must be comparable, got AggregateFunction(avg, UInt64) type for column v instead. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Storages/MergeTree/MergeTreeIndexMinMax.cpp:0: DB::minmaxIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000012879d9f 5. /build/contrib/llvm-project/libcxx/include/unordered_set:785: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277daa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.476735 [ 8473 ] {5cc7f89a-62e2-4c69-a388-4b70f99c6055} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45054) (comment: 02810_convert_uuid_to_uint128.sql) (in query: SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsConversion.cpp:1664: 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&&) @ 0x000000000714f9e6 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/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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:16:36.482822 [ 8473 ] {5cc7f89a-62e2-4c69-a388-4b70f99c6055} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsConversion.cpp:1664: 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&&) @ 0x000000000714f9e6 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/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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:16:36.536668 [ 2928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.663878 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:36.664441 [ 8473 ] {675b5c0c-d414-49c6-89b1-8059de03c4dd} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:45054) (comment: 02810_convert_uuid_to_uint128.sql) (in query: SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsConversion.cpp:1664: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, 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)::NameToInt128, 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&&) @ 0x00000000071bc7be 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071b6628 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:16:36.667048 [ 8473 ] {675b5c0c-d414-49c6-89b1-8059de03c4dd} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/FunctionsConversion.cpp:1664: bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, 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)::NameToInt128, 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&&) @ 0x00000000071bc7be 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000071b6628 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&) @ 0x0000000011050d10 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:16:36.733807 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:36.754035 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.09.25 21:16:36.755583 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} Cluster: Code: 198. DB::NetException: Not found address of host: localhosy. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:855: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000011551f05 14. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011556ffc 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.008736 [ 3459 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.011004 [ 3001 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.053865 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.313835 [ 3196 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.428731 [ 3157 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.578387 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:37.735882 [ 3158 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:37.786831 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:38.011152 [ 3414 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.013246 [ 3414 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.056537 [ 3362 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.396978 [ 3118 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.431518 [ 3060 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.549438 [ 2928 ] {8ff6745d-945a-424d-8581-3a26e31a0b66} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35836) (in query: select n, _table from test_1ddgrpt9.merge 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:16:38.604047 [ 2928 ] {8ff6745d-945a-424d-8581-3a26e31a0b66} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5e7f7 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&)>) @ 0x0000000011913de8 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.670260 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:38.738257 [ 3128 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:38.921623 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:39.013372 [ 3104 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.015838 [ 3104 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.059436 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.192467 [ 4665 ] {d14bb484-7ccc-4e1a-a1df-639f5eac9ff4} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37292) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT UUIDStringToNum('00112233-4455-6677-8899-aabbccddeeff', materialize(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:16:39.195233 [ 4665 ] {d14bb484-7ccc-4e1a-a1df-639f5eac9ff4} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:16:39.399876 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.443714 [ 3371 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.455507 [ 4665 ] {2b7db018-38da-42e4-ad83-06e7eac489ab} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37292) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT 'a/<@];!~p{jTj={)' AS bytes, UUIDNumToString(toFixedString(bytes, 16), materialize(2)) AS uuid;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:16:39.459058 [ 4665 ] {2b7db018-38da-42e4-ad83-06e7eac489ab} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:16:39.741063 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:39.914746 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:40.015705 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.017909 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.061229 [ 3159 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.209739 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:40.413428 [ 3392 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.446500 [ 3057 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.524968 [ 5600 ] {c33379c6-9f63-4ad1-aac5-e840ee9b1f63} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54848) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:40.534164 [ 5600 ] {c33379c6-9f63-4ad1-aac5-e840ee9b1f63} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.743825 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:40.898542 [ 4665 ] {5575dfff-9ff2-4a59-8d5b-94aa934f3248} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54850) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:40.906713 [ 4665 ] {5575dfff-9ff2-4a59-8d5b-94aa934f3248} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.018186 [ 3321 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.020198 [ 3401 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.042587 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.063705 [ 3160 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.180484 [ 5600 ] {81a5a76c-fabc-46fd-b266-3919d8874d01} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54856) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.191068 [ 5600 ] {81a5a76c-fabc-46fd-b266-3919d8874d01} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.235574 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.416140 [ 3191 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.452699 [ 3177 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.505956 [ 4665 ] {80bc1f1d-efc0-44b4-a5e2-2ab99ede3717} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54862) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.508397 [ 4665 ] {80bc1f1d-efc0-44b4-a5e2-2ab99ede3717} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.637082 [ 5600 ] {a71c3e5e-8994-4517-ae7e-4f084f8c9a19} executeQuery: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37356) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`sub_key` AS `sub_key` FROM `test_13`.`dist_layer_01319` AS `__table1` WHERE `__table1`.`key` = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001223353c 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.642890 [ 5600 ] {a71c3e5e-8994-4517-ae7e-4f084f8c9a19} TCPHandler: Code: 507. DB::Exception: Sharding key sub_key is not used. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001223353c 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.743005 [ 7902 ] {171242d5-81e3-4c57-bab8-c12a10fa9def} executeQuery: Code: 507. DB::Exception: Received from localhost:9000. DB::Exception: Sharding key sub_key is not used. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001223353c 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 : While executing Remote. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37336) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: select * from dist_01319 where key = 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:16:41.746649 [ 7902 ] {171242d5-81e3-4c57-bab8-c12a10fa9def} TCPHandler: Code: 507. DB::Exception: Received from localhost:9000. DB::Exception: Sharding key sub_key is not used. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001223353c 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223244c 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) @ 0x00000000116682b7 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&) @ 0x000000001166213c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 : While executing Remote. (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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:16:41.763699 [ 3430 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.776171 [ 2929 ] {681ee0d8-b4e9-4638-a699-8ff708fbea69} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54878) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.792014 [ 2929 ] {681ee0d8-b4e9-4638-a699-8ff708fbea69} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:41.949118 [ 5600 ] {d83e6e7a-b4e1-481c-a37f-efb45f211a62} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54886) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:41.960495 [ 5600 ] {d83e6e7a-b4e1-481c-a37f-efb45f211a62} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.020588 [ 3381 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.022356 [ 3322 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.069243 [ 3370 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.076070 [ 4665 ] {06e6bd76-e3f7-4724-ae28-5aab6e5f0465} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54894) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.086742 [ 4665 ] {06e6bd76-e3f7-4724-ae28-5aab6e5f0465} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.192433 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.256618 [ 5600 ] {2b7eec07-6bd6-4262-a626-cb719ce51408} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54896) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.261004 [ 5600 ] {2b7eec07-6bd6-4262-a626-cb719ce51408} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.356731 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.357506 [ 2929 ] {2c3f4b3a-3b68-44c2-a81b-5eb396913d1a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54900) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.418655 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.436128 [ 2929 ] {2c3f4b3a-3b68-44c2-a81b-5eb396913d1a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.455044 [ 3444 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.484924 [ 4665 ] {0160877f-1fd1-4ab2-a223-06e43fe44576} 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.10508.altinitytest (altinity build)) (from [::1]:37370) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`sub_key` AS `sub_key` FROM `test_13`.`dist_layer_01319` AS `__table1` WHERE `__table1`.`key` = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.489057 [ 4665 ] {0160877f-1fd1-4ab2-a223-06e43fe44576} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.510666 [ 7902 ] {c9c8eb2c-28fd-45f0-9f2e-8c98fda37863} executeQuery: Code: 439. DB::Exception: Received from localhost:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37336) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: select * from dist_01319 where key = 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:16:42.513447 [ 7902 ] {c9c8eb2c-28fd-45f0-9f2e-8c98fda37863} TCPHandler: Code: 439. DB::Exception: Received from localhost:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:16:42.530041 [ 5600 ] {7b65909f-348a-442a-8151-753c91085169} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54902) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.532204 [ 5600 ] {7b65909f-348a-442a-8151-753c91085169} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.555434 [ 4693 ] {71d1df14-19bc-4f64-ac29-84e6d30d466d} 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]:53210). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53210) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`sub_key` AS `sub_key` FROM `test_13`.`data_01319` AS `__table1` WHERE `__table1`.`key` = 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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.561124 [ 4693 ] {71d1df14-19bc-4f64-ac29-84e6d30d466d} 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]:53210). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.568016 [ 4693 ] {71d1df14-19bc-4f64-ac29-84e6d30d466d} TCPHandler: Client has gone away. 2025.09.25 21:16:42.699378 [ 4665 ] {2710ff66-1388-44dd-80ce-062e7842cdf1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54918) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.703262 [ 4665 ] {2710ff66-1388-44dd-80ce-062e7842cdf1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.765830 [ 2970 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:42.881692 [ 5600 ] {62527012-b882-4147-b71b-03e962bedcf0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54930) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_jmp53t1k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:16:42.900346 [ 5600 ] {62527012-b882-4147-b71b-03e962bedcf0} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.002923 [ 3202 ] {} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.09.25 21:16:43.025084 [ 3178 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.026832 [ 3384 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.074606 [ 3427 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.088675 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:43.403843 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:43.421624 [ 3250 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.457433 [ 3040 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:43.768787 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.027790 [ 3478 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.029749 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.077302 [ 3205 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.244816 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:44.463184 [ 3223 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.463626 [ 3313 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:44.603873 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:44.771608 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.030272 [ 3071 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.032449 [ 3077 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.080078 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.369716 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:45.465950 [ 3090 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.466495 [ 3272 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:45.715832 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:45.773974 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.032574 [ 3350 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.034910 [ 3053 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.083005 [ 3140 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.460537 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:46.470118 [ 3292 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.470513 [ 3235 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:46.730590 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:46.775805 [ 3470 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.034521 [ 3014 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.036849 [ 3404 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.085529 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.393155 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:47.471753 [ 3083 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.472167 [ 3420 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:47.632155 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:47.777674 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.036132 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.038305 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.087133 [ 3312 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.323405 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:48.473568 [ 3152 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.473718 [ 3249 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.529904 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:48.779600 [ 2965 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:48.992187 [ 4665 ] {8a0e270d-f77c-4e9b-9a54-1a4882f9b0b0} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37378) (comment: 03033_recursive_cte_basic.sql) (in query: WITH RECURSIVE recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10) SELECT n FROM recursive_cte FORMAT Null SETTINGS max_recursive_cte_evaluation_depth = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x0000000008a8f36b 4. /build/src/Processors/Sources/RecursiveCTESource.cpp:0: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000131d82fe 5. /build/src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x00000000131d7921 6. /build/src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x00000000131d76d0 7. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 14. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:49.001428 [ 4665 ] {8a0e270d-f77c-4e9b-9a54-1a4882f9b0b0} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x0000000008a8f36b 4. /build/src/Processors/Sources/RecursiveCTESource.cpp:0: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x00000000131d82fe 5. /build/src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x00000000131d7921 6. /build/src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x00000000131d76d0 7. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 14. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:49.041431 [ 3324 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:49.041595 [ 3109 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:49.089034 [ 3263 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:49.228260 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:49.387684 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:49.546201 [ 2992 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:49.546259 [ 3252 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:49.781609 [ 3093 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.043988 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.044214 [ 3204 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.090723 [ 3276 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.097601 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:50.300162 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:50.548666 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.550619 [ 3148 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:50.783944 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.008619 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.09.25 21:16:51.046428 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.047348 [ 3186 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.060113 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} Cluster: Code: 198. DB::NetException: Not found address of host: localhosx. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1650: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d4c5 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.093142 [ 3046 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.102227 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:51.397716 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:51.552263 [ 2991 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.553317 [ 3378 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:51.794806 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.048873 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.050236 [ 3405 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.095605 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.318947 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:52.515837 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:52.555225 [ 3146 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.559358 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:52.797519 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.052900 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.055423 [ 3308 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.101076 [ 3238 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.427256 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:53.557759 [ 3290 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.561790 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:53.741295 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:53.800238 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.055414 [ 3314 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.057982 [ 3174 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.103900 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.560269 [ 3408 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.564500 [ 3459 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:54.636273 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:54.796544 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:54.803397 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.057761 [ 3440 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.063080 [ 3097 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.106337 [ 3166 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.565700 [ 3456 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.567439 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.773252 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:55.808111 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:55.938029 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:56.059450 [ 3143 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.065266 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.113871 [ 3188 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.568012 [ 3179 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.569556 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.795524 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:56.810662 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:56.925378 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:57.061764 [ 3141 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.073610 [ 3346 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.116637 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.570187 [ 3113 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.573580 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.813582 [ 3033 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:57.833241 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:58.034606 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:58.064567 [ 3010 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.076550 [ 3159 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.114632 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {53303125-9975-4221-b621-bca733688e45::202509_1_65_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.119991 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.578349 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.581245 [ 3102 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.816190 [ 3332 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:58.946910 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:59.014839 [ 3202 ] {} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.09.25 21:16:59.066967 [ 3160 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.078986 [ 3370 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.125782 [ 3464 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.214091 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:16:59.582807 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.583455 [ 3488 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.818072 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:16:59.836695 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:00.069064 [ 3427 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:00.131884 [ 3288 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:00.132119 [ 3442 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:00.165862 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:00.586591 [ 3149 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:00.589359 [ 3227 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:00.820493 [ 2994 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.017114 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:01.071402 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.142970 [ 3343 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.144307 [ 3180 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.289028 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:01.589542 [ 3020 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.592220 [ 3337 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.822410 [ 3422 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:01.932119 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:02.074208 [ 3205 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.145518 [ 3404 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.147488 [ 3423 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.217233 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:02.592070 [ 3146 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.594916 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.699426 [ 3594 ] {2777f36b-f05d-403e-ac05-44e247b0acba::202509_1_36_7_39} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.710166 [ 3594 ] {2777f36b-f05d-403e-ac05-44e247b0acba::202509_1_36_7_39} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.826109 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:02.921417 [ 7902 ] {9d6b82b2-f508-4a97-9d2e-67c6f15353b6} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_39.txt' with part '202509_1_36_7' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.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.10508.altinitytest (altinity build)) (from [::1]:35890) (comment: 02834_remote_session_log.sh) (in query: DELETE FROM system.session_log WHERE user = '02834_USER_70115'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&) @ 0x00000000128c1d4b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1c83 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bc9a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cb24 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x000000001198187f 10. /build/src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x000000001197fef8 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:17:02.937818 [ 7902 ] {9d6b82b2-f508-4a97-9d2e-67c6f15353b6} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_39.txt' with part '202509_1_36_7' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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&) @ 0x00000000128c1d4b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1c83 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bc9a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cb24 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x000000001198187f 10. /build/src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x000000001197fef8 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:17:03.095662 [ 3481 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:03.109488 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:03.148061 [ 3286 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:03.150138 [ 3108 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:03.383013 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:03.594628 [ 3175 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:03.597443 [ 3400 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:03.881004 [ 3454 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.106502 [ 3039 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.150171 [ 3162 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.159542 [ 3369 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.309171 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:04.537635 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:04.600422 [ 3363 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.597318 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:04.883426 [ 3247 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.110994 [ 3172 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.154354 [ 3111 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.162834 [ 3233 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.395069 [ 5326 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:05.485834 [ 4994 ] {904c2da7-e2b4-47e4-afbf-169be0757152} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35926) (comment: 00555_hasAll_hasAny.sql) (in query: select hasAny([], []);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:17:05.489633 [ 4994 ] {904c2da7-e2b4-47e4-afbf-169be0757152} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:17:05.603336 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.608345 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:05.689751 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:05.888271 [ 3080 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.113130 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.157140 [ 3312 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.165572 [ 3170 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.419867 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:06.606331 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.610982 [ 3360 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:06.777966 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:06.890763 [ 2993 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.020283 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.09.25 21:17:07.022911 [ 7898 ] {191e210c-6fc1-4a7e-a709-df147e37587c} Cluster: Code: 198. DB::NetException: Not found address of host: localhosy. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1650: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155d4c5 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.115338 [ 3116 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.159282 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.171542 [ 3428 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.331601 [ 7902 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.546799 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:07.609123 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.614273 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:07.784853 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:07.894883 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.118640 [ 3204 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.161730 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.174476 [ 3079 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.611659 [ 3388 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.616763 [ 3408 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:08.695254 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:08.866934 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:08.898085 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.122046 [ 3186 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.164208 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.182397 [ 3467 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.414861 [ 2955 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012515731 9. /build/src/Storages/StorageBuffer.cpp:1088: DB::StorageBuffer::backgroundFlush() @ 0x0000000012518c92 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.613978 [ 3287 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.622558 [ 3459 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.823777 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:09.903921 [ 3135 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:09.984955 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:10.124486 [ 3294 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:10.169761 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:10.184597 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:10.616363 [ 3358 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:10.624396 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:10.738736 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:10.905975 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.072759 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:11.127339 [ 2984 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.172703 [ 3269 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.188192 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.618650 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.626191 [ 3167 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:11.780659 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:11.911170 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.082746 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:12.129866 [ 3309 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.137880 [ 7898 ] {c690f90e-7023-41ad-8b9a-cf9d466a27f7} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56308) (comment: 01083_expressions_in_engine_arguments.sql) (in query: DROP DICTIONARY dict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:17:12.143320 [ 7898 ] {c690f90e-7023-41ad-8b9a-cf9d466a27f7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:17:12.175415 [ 3334 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.196940 [ 3118 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.473602 [ 7902 ] {88420451-9f46-4ab4-a76f-3a24b2ad0a9f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46302) (comment: 01083_expressions_in_engine_arguments.sql) (in query: DROP DATABASE IF EXISTS test_1ddgrpt9 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:17:12.476457 [ 7902 ] {88420451-9f46-4ab4-a76f-3a24b2ad0a9f} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.624669 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.628930 [ 3470 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:12.831439 [ 4693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:12.913493 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.115147 [ 4693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:13.132798 [ 3244 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.177126 [ 3221 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.199282 [ 3042 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.627421 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.721353 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:13.881537 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:13.915959 [ 3188 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.135763 [ 3444 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.179485 [ 3040 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.204598 [ 3329 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.207709 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:14.629420 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.724256 [ 3415 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:14.917984 [ 3059 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.006750 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:15.143968 [ 3448 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.192758 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.207592 [ 3090 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.279575 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:15.664880 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.726864 [ 3163 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:15.924238 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.044921 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:16.145912 [ 3232 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.194744 [ 2991 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.206189 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:16.210328 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.670283 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.729142 [ 3473 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:16.927033 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.148392 [ 3457 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.165518 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:17.197027 [ 3324 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.213072 [ 2981 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.423703 [ 4693 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.449755 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:17.672229 [ 3325 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.731330 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:17.929528 [ 3047 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.151776 [ 3180 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.203942 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.218710 [ 3295 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.218670 [ 3588 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_98_125_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.285745 [ 4693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:18.659357 [ 4693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:18.677531 [ 3017 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.733837 [ 3128 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:18.932020 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.154169 [ 3134 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.208506 [ 3266 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.271762 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.391438 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:19.680237 [ 3475 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.736505 [ 3045 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:19.826232 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:19.934599 [ 2987 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.156630 [ 3423 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.210625 [ 3428 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.274310 [ 3453 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.568092 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:20.682635 [ 3447 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.747822 [ 3224 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.937605 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:20.998566 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:21.159851 [ 3108 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:21.213364 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:21.302895 [ 3209 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:21.685018 [ 3277 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:21.752170 [ 3301 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:21.773484 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:21.775712 [ 4693 ] {15ceded3-2139-4993-87cc-fb4b089dadb5} executeQuery: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38400) (comment: 02382_analyzer_matcher_join_using.sql) (in query: SELECT * FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (id, id, id) ORDER BY id, t1.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011062cfb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:17:21.785143 [ 4693 ] {15ceded3-2139-4993-87cc-fb4b089dadb5} TCPHandler: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011062cfb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:17:21.940584 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.165065 [ 3369 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.215843 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.268495 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:22.400094 [ 3380 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.691019 [ 3124 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.764320 [ 3255 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:22.887753 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:22.943665 [ 3130 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.168004 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.232678 [ 3276 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.341191 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:23.401956 [ 3151 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.693456 [ 3468 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.770920 [ 3376 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:23.869556 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:23.946336 [ 2997 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.170370 [ 3116 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.234942 [ 3246 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.404641 [ 3409 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.500173 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:24.696271 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.773475 [ 3372 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:24.994213 [ 3297 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.088155 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:25.172400 [ 2979 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.237535 [ 3418 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.410324 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.656107 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:25.698912 [ 3300 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.777163 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:25.997150 [ 3261 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:26.173221 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:26.174622 [ 3026 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:26.239848 [ 3206 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:26.418639 [ 3191 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:26.520885 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:26.700770 [ 3267 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:26.779539 [ 3241 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.000788 [ 3197 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.177344 [ 3186 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.222557 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:27.241515 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.420325 [ 3318 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.444300 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:27.706988 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:27.781766 [ 3098 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.003531 [ 3414 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.179967 [ 3066 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.243818 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.387779 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:28.422720 [ 3489 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.594400 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:28.709621 [ 3430 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:28.786754 [ 2977 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.005316 [ 3101 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.184217 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.245675 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.309939 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:29.428948 [ 3157 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.471418 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:29.713366 [ 3260 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:29.790285 [ 3093 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.010277 [ 3044 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.172402 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:30.185942 [ 3477 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.247729 [ 3120 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.384218 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:30.432680 [ 3060 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.715606 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:30.792204 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.013102 [ 3391 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.188479 [ 3054 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.249981 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.255759 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:31.434661 [ 3221 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.532081 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:31.718386 [ 3368 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:31.794530 [ 3365 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.018632 [ 3278 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.194057 [ 3220 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.252720 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.350766 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:32.437182 [ 3068 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.720862 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:32.774698 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:32.796787 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.021461 [ 3416 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.196472 [ 3410 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.254390 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.443762 [ 3152 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.496327 [ 4994 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:33.723822 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:33.799207 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.014869 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:34.033273 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.198874 [ 3253 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.256406 [ 3232 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.446474 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.595240 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:34.725480 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.809921 [ 3217 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:34.959900 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:35.038679 [ 3471 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:35.203269 [ 2995 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:35.259135 [ 3458 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:35.449488 [ 3013 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:35.659986 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:35.727842 [ 3009 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:35.820912 [ 3365 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.041164 [ 3296 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.200241 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:36.205443 [ 3263 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.261778 [ 3405 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.451710 [ 3421 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.730292 [ 3158 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:36.776161 [ 7933 ] {3744d384-931e-4d01-91bd-b04e026f2ae6} 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.10508.altinitytest (altinity build)) (from [::1]:36982) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7349 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e45c7 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) @ 0x00000000116ded14 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) @ 0x00000000116de1bd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f05b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:17:36.780451 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:36.798988 [ 7933 ] {3744d384-931e-4d01-91bd-b04e026f2ae6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7349 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e45c7 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) @ 0x00000000116ded14 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) @ 0x00000000116de1bd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f05b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:17:36.823478 [ 3359 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.044492 [ 3137 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.208424 [ 3393 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.264472 [ 3082 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.457148 [ 3177 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.499440 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:37.543709 [ 4994 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.733077 [ 3128 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.803709 [ 7898 ] {3fd89a25-ce44-4ed3-9f78-476bb15ef8a9} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37012) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010ce63aa 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce62fe 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&&) @ 0x00000000116ece18 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8613 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eab36 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f068 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:17:37.832503 [ 2988 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:37.840690 [ 7898 ] {3fd89a25-ce44-4ed3-9f78-476bb15ef8a9} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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 @ 0x0000000010ce63aa 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce62fe 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9570 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 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) @ 0x0000000010fcb9e1 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&&) @ 0x00000000116ece18 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8613 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eab36 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f068 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 2025.09.25 21:17:37.999029 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:38.046797 [ 3270 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.210827 [ 3307 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.266843 [ 3453 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.462175 [ 3173 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.585906 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:38.734746 [ 3045 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.836141 [ 3088 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:38.928183 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:39.049508 [ 3071 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.154760 [ 3596 ] {} f7f14165-0845-456b-9071-43177b397276::20000101_20000101_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.156986 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7f14165-0845-456b-9071-43177b397276::20000101_20000101_1_1_0_2}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.212751 [ 2981 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.268845 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.468399 [ 3315 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.552349 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:39.738839 [ 3255 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:39.837893 [ 3153 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.023765 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:40.058181 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.214222 [ 3443 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.270785 [ 3182 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.470526 [ 3272 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.506733 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:40.715603 [ 3240 ] {} test_3.alter_compression_codec1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.724507 [ 3300 ] {} test_13.forget_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.728206 [ 3189 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.745206 [ 3132 ] {} test_13.deduplication_by_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.745664 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:40.747332 [ 2970 ] {} test_wyw4huqy.mutations_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.749326 [ 3260 ] {} test_wyw4huqy.mutations_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.752484 [ 3203 ] {} test_3.alter_compression_codec2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:17:40.822222 [ 8473 ] {bc229d5e-0449-4da7-beb6-57d6fcf07bf2} executeQuery: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37118) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 DELETE WHERE s = 'd' SETTINGS mutations_sync = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000012a43e1b 3. /build/src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x00000000134b4f30 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x00000000134affb6 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afbac 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000134b0c65 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013461f5c 8. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000013461b07 9. /build/src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000013462659 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 11. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 12. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000123ff57c 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:17:40.835428 [ 8473 ] {bc229d5e-0449-4da7-beb6-57d6fcf07bf2} TCPHandler: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000012a43e1b 3. /build/src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x00000000134b4f30 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x00000000134affb6 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1208: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000134afbac 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000134b0c65 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013461f5c 8. /build/contrib/llvm-project/libcxx/include/__chrono/duration.h:258: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000013461b07 9. /build/src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000013462659 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000013462396 11. /build/src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000134621f8 12. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000123ff57c 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:17:40.840095 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.061032 [ 3427 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.103807 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:41.218243 [ 3295 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.272407 [ 3190 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.473047 [ 3419 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.535174 [ 7898 ] {943db8a5-4dcc-4508-8d39-73a41629bf4a} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37132) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 DELETE WHERE m = 3 SETTINGS mutations_sync = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012400901 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:17:41.546962 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:41.565084 [ 7898 ] {943db8a5-4dcc-4508-8d39-73a41629bf4a} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:7530: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012400901 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f0fb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:17:41.747889 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:41.842487 [ 2985 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.062793 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.131513 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:42.223310 [ 3428 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.274591 [ 3120 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.520633 [ 3016 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.634263 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:42.752885 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:42.844830 [ 3188 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.068428 [ 3481 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.234518 [ 3276 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.277109 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:43.277296 [ 3123 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.523314 [ 3466 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.756487 [ 3217 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.846688 [ 3234 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:43.868452 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:44.070770 [ 3039 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:44.236956 [ 3206 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:44.279636 [ 3308 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:44.365132 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:44.526656 [ 3253 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:44.759493 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:44.849568 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.077355 [ 3053 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.163155 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:45.239356 [ 3455 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.282411 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.479063 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:45.529232 [ 3192 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.761772 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:45.851997 [ 3096 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.080629 [ 3472 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.242041 [ 3356 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.285429 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.476753 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:46.532133 [ 3230 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.682171 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:46.764400 [ 3019 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:46.854468 [ 3194 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.083503 [ 3060 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.247694 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.291857 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.534992 [ 3389 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.737146 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:47.770115 [ 3292 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:47.864534 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:47.919691 [ 3018 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.086817 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.250185 [ 3152 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.294316 [ 2992 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.537608 [ 3265 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.772873 [ 3146 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.917273 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:48.921938 [ 2967 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:48.935626 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:49.090126 [ 3283 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:49.253277 [ 3023 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:49.297232 [ 3166 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:49.540764 [ 3052 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:49.775784 [ 3198 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:49.927798 [ 3450 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.040337 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:50.066009 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:50.093813 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.256196 [ 3161 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.299677 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.543524 [ 3331 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.778261 [ 2964 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:50.930596 [ 3367 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.097035 [ 3427 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.265069 [ 3467 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.276463 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:51.288965 [ 7902 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:51.302116 [ 3209 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.546516 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.787913 [ 2974 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:51.933056 [ 3047 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.099575 [ 3481 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.267903 [ 3257 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.305269 [ 3213 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.511590 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:52.557136 [ 3061 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.645850 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:52.790354 [ 3127 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:52.935621 [ 3379 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.104942 [ 3000 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.270401 [ 3453 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.311164 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.495231 [ 3600 ] {} 6b7d0e3e-1f13-48a8-9153-45e677a3eab0::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.496824 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b7d0e3e-1f13-48a8-9153-45e677a3eab0::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.559610 [ 3004 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.605987 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:53.617828 [ 3602 ] {} 9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_1 (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.620062 [ 3602 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_1}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.792817 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:53.856756 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:53.938326 [ 3342 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.107802 [ 3133 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.275771 [ 3069 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.313675 [ 3238 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.573947 [ 3179 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.691742 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:54.795686 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:54.941480 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.103803 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:55.109954 [ 3044 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.278394 [ 3425 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.316279 [ 2986 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.576681 [ 3095 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.798094 [ 3093 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:55.825483 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:55.943304 [ 3188 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.110523 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:56.112511 [ 3172 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.158952 [ 3601 ] {} 9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.160161 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_2}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.280955 [ 3110 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.318118 [ 3058 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.358447 [ 3596 ] {} 6b7d0e3e-1f13-48a8-9153-45e677a3eab0::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000128fec5a 17. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 19. /build/src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e88b1 20. /build/src/QueryPipeline/QueryPipelineBuilder.h:160: DB::MutationsInterpreter::execute() @ 0x00000000116eb011 21. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x000000001296491a 22. /build/src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000012963191 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c89b9 24. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7796 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.367516 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b7d0e3e-1f13-48a8-9153-45e677a3eab0::all_0_0_0_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000128fec5a 17. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 19. /build/src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e88b1 20. /build/src/QueryPipeline/QueryPipelineBuilder.h:160: DB::MutationsInterpreter::execute() @ 0x00000000116eb011 21. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x000000001296491a 22. /build/src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000012963191 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c89b9 24. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7796 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.579036 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.701223 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:56.801885 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:56.945650 [ 3374 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.124340 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.159748 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:57.288484 [ 3190 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.320252 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.581358 [ 3227 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.677442 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:57.812092 [ 3403 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:57.947846 [ 3218 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.112343 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:58.126715 [ 3391 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.295906 [ 3387 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.322135 [ 3118 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.586738 [ 3122 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.675883 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:58.814688 [ 3437 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:58.950247 [ 3059 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.076764 [ 3587 ] {} 9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.078730 [ 3587 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.202768 [ 3276 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.298060 [ 3103 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.323193 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:59.324472 [ 3392 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.580492 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:17:59.589375 [ 3174 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.819681 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:17:59.953122 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.210994 [ 3107 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.309075 [ 3191 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.329147 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.435209 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:00.444437 [ 3601 ] {} 9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.453673 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9bb93b4c-f526-4544-a3ac-2e2b270eece7::all_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.509273 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:00.593523 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.822308 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:00.955650 [ 3411 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.213824 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.314683 [ 3042 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.331633 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.550005 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:01.558206 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:01.596847 [ 2989 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.824511 [ 3414 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:01.957666 [ 3381 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.216156 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.316687 [ 3083 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.333935 [ 3219 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.487494 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:02.494798 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:02.598933 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.826353 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:02.959338 [ 3138 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.218294 [ 2981 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.318568 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.336042 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.361803 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:03.383319 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:03.601129 [ 3337 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.828293 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:03.960937 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.218795 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:04.220436 [ 3295 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.275560 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:04.320624 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.338359 [ 3327 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.603773 [ 3175 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.835147 [ 3025 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:04.963090 [ 3320 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.224597 [ 3428 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.326439 [ 3007 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.345726 [ 3030 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.462370 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:05.480027 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:05.606500 [ 3106 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.842464 [ 2999 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:05.966191 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.227047 [ 3204 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.328738 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.356770 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.583304 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:06.590662 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:06.613865 [ 3400 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.845114 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:06.969269 [ 3100 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.278808 [ 3453 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.338337 [ 3165 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.363221 [ 3199 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.616123 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.674812 [ 4994 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.703265 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:07.759769 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:07.847789 [ 3480 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:07.971724 [ 3245 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.281505 [ 3110 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.345115 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.365305 [ 3058 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.621518 [ 3290 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.843800 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:08.850080 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:08.919421 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:08.973972 [ 3217 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.284624 [ 3190 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.347623 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.367529 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.573326 [ 4994 ] {dc175cfd-a72e-4728-af99-f7460e773830} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40738) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_wyw4huqy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:09.596063 [ 4994 ] {dc175cfd-a72e-4728-af99-f7460e773830} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.624386 [ 3311 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.747482 [ 5600 ] {f2589e16-a8c3-4ea4-807c-ff03ea946bff} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40754) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_wyw4huqy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:09.760301 [ 5600 ] {f2589e16-a8c3-4ea4-807c-ff03ea946bff} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.856190 [ 3437 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.927869 [ 7615 ] {bc3c809b-c488-4f4a-b349-562c73868411} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40770) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_wyw4huqy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:09.930672 [ 7615 ] {bc3c809b-c488-4f4a-b349-562c73868411} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:09.986593 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:10.027215 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.060071 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:10.075626 [ 8473 ] {2c23cf99-deb8-41d3-aa74-b83f74cb379c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40780) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_wyw4huqy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:10.081922 [ 8473 ] {2c23cf99-deb8-41d3-aa74-b83f74cb379c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.288011 [ 3316 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.349955 [ 3043 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.369924 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.630398 [ 2983 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:10.874368 [ 3064 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.029685 [ 3270 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.165297 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:11.290663 [ 3120 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.330087 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:11.352352 [ 3323 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.372720 [ 3309 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.633652 [ 3154 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:11.877436 [ 3231 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.032390 [ 3178 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.293416 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.336706 [ 7615 ] {9abfe319-2bef-4aae-85e4-7a7c0c9b0b8e} executeQuery: Code: 57. DB::Exception: Table test_ayu2cn4o.dict_invalidate already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52852) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (in query: CREATE TABLE dict_invalidate ENGINE = Memory AS SELECT 133 as dummy, toDateTime('2019-10-29 18:51:35') AS last_time FROM system.one), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:18:12.357609 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.368853 [ 7615 ] {9abfe319-2bef-4aae-85e4-7a7c0c9b0b8e} TCPHandler: Code: 57. DB::Exception: Table test_ayu2cn4o.dict_invalidate 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:18:12.377923 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:12.381372 [ 3334 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.535523 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:12.639856 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:12.880284 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.034905 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.295893 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.393043 [ 3118 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.395237 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.615944 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:13.642040 [ 3388 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:13.812360 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:13.886023 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.037590 [ 3071 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.297931 [ 3392 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.395327 [ 3060 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.397301 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.479866 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:14.646086 [ 3119 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:14.689121 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:14.890996 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.040065 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.299847 [ 3402 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.397425 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.399134 [ 3419 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.456868 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:15.634783 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:15.648591 [ 3023 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:15.893663 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.041845 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.209577 [ 8473 ] {d915b103-3fbc-41d8-b16b-a0a2d2ed2b9c} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40800) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (in query: DROP DATABASE IF EXISTS test_ayu2cn4o ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:16.214879 [ 8473 ] {d915b103-3fbc-41d8-b16b-a0a2d2ed2b9c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.301969 [ 3139 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.401092 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.403697 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.501158 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:16.655875 [ 3289 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:16.694387 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:16.903320 [ 3433 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.044130 [ 3181 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.305554 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.402880 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.405480 [ 3325 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.521857 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:17.642590 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:17.658178 [ 3413 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:17.905409 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.045885 [ 3137 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.307495 [ 3209 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.411585 [ 3302 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.412735 [ 3019 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.438349 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:18.606686 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:18.660593 [ 2995 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.665017 [ 17872 ] {47cdc4fc-89c2-4b47-9362-fd3fdbdfa740} test_pb1ugd7u.rmt (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/c40/c40d1a37-cefb-4615-8bef-537e6b86be22/0_0_0_0/columns.txt: , errno: 2, strerror: No such file or directory. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e455 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000c69e262 5. ? @ 0x00000000104cdbf0 6. /build/src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x00000000104cdc22 7. /build/src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000104c9440 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x00000000104c8fdf 9. /build/src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x00000000104c8ed4 10. /build/src/Disks/DiskLocal.cpp:334: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000010ef8fce 11. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:127: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000126b87e8 12. /build/src/Storages/MergeTree/checkDataPart.cpp:0: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x0000000012a678be 13. /build/src/Storages/MergeTree/checkDataPart.cpp:419: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x0000000012a674e2 14. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x00000000129ea1c9 15. /build/src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x00000000129ecb5b 16. /build/contrib/llvm-project/libcxx/include/string:2067: DB::StorageReplicatedMergeTree::checkDataNext(std::shared_ptr&) @ 0x000000001241d5a4 17. /build/contrib/llvm-project/libcxx/include/optional:344: DB::(anonymous namespace)::TableCheckWorkerProcessor::transform(DB::Chunk&) @ 0x000000001196ac29 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 19. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 21. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:18.666883 [ 17872 ] {47cdc4fc-89c2-4b47-9362-fd3fdbdfa740} test_pb1ugd7u.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.09.25 21:18:18.669484 [ 17872 ] {47cdc4fc-89c2-4b47-9362-fd3fdbdfa740} test_pb1ugd7u.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.09.25 21:18:18.672736 [ 17872 ] {47cdc4fc-89c2-4b47-9362-fd3fdbdfa740} test_pb1ugd7u.rmt (c40d1a37-cefb-4615-8bef-537e6b86be22): Detached 1 parts covered by broken part 0_0_0_0: 0_0_0_0 2025.09.25 21:18:18.728426 [ 17872 ] {47cdc4fc-89c2-4b47-9362-fd3fdbdfa740} InterpreterCheckQuery: Check query for table test_pb1ugd7u.rmt (c40d1a37-cefb-4615-8bef-537e6b86be22) failed, path 0_0_0_0, reason: Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.09.25 21:18:18.785357 [ 3255 ] {} test_pb1ugd7u.rmt (c40d1a37-cefb-4615-8bef-537e6b86be22): Directory /var/lib/clickhouse/store/c40/c40d1a37-cefb-4615-8bef-537e6b86be22/0_0_0_0 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.09.25 21:18:18.907024 [ 2978 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.047467 [ 3178 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.309459 [ 3065 ] {} test_pb1ugd7u.rmt (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.09.25 21:18:19.374838 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.398424 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:19.414893 [ 3318 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.421384 [ 3318 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.590474 [ 3065 ] {} test_pb1ugd7u.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 is lost forever. 2025.09.25 21:18:19.626117 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:19.662981 [ 3023 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:19.911527 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.049222 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.291684 [ 7934 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:20.376636 [ 3309 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.417058 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.423289 [ 3221 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.661729 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:20.665097 [ 3289 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:20.913464 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.051969 [ 3027 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.174389 [ 3592 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1aef7ea7-cbf0-4db2-93e7-d853aa133566::202509_1_124_35}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.215616 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:21.378652 [ 3355 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.419323 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.425206 [ 3040 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.463123 [ 7898 ] {11856883-4d3b-42b4-b5d2-4885f3be3aa8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43476) (comment: 02253_empty_part_checksums.sh) (in query: select name, part_type, hash_of_all_files, hash_of_uncompressed_files, uncompressed_hash_of_compressed_files from system.parts where 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:18:21.472174 [ 7898 ] {11856883-4d3b-42b4-b5d2-4885f3be3aa8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:18:21.602274 [ 17855 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x0000000012a43e1b 3. /build/src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x00000000134b4f30 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x00000000134af696 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:846: Coordination::ZooKeeper::receiveEvent() @ 0x00000000134ae72c 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x00000000134ade30 7. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000134b3f87 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.628384 [ 3311 ] {} test_3.alter_compression_codec1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.630353 [ 3155 ] {} test_13.forget_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.632067 [ 3360 ] {} test_pb1ugd7u.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.634002 [ 3174 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.642124 [ 3375 ] {} test_13.deduplication_by_partition (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.650401 [ 3283 ] {} test_3.alter_compression_codec2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.25 21:18:21.667168 [ 3185 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.675260 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:21.763612 [ 3279 ] {} test_pb1ugd7u.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_pb1ugd7u/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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*&&, String const&) @ 0x000000001045306b 4. /build/src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000104526ab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000001346193a 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001345f408 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000129d0297 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000129cf79c 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000129ce89a 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 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*) @ 0x000000001096ab87 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:21.915885 [ 3490 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.054565 [ 3362 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.381251 [ 3448 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.406337 [ 7934 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:22.422784 [ 3219 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.427922 [ 2992 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.669441 [ 3267 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.921544 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:22.999181 [ 7934 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:23.060137 [ 3427 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.383937 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.425179 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.430131 [ 3091 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.547441 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:23.671461 [ 2990 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.923577 [ 3143 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:23.946253 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:24.062182 [ 3386 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.386133 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.427654 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.432235 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.542633 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:24.675407 [ 3048 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.925519 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:24.948725 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:25.064286 [ 3171 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:25.388487 [ 3368 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:25.474320 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:25.474464 [ 3201 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:25.600695 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:25.681423 [ 3072 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:25.921751 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:25.927479 [ 3222 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.066376 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.391265 [ 3135 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.476814 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.477341 [ 2987 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.684030 [ 3379 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:26.695052 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:26.929455 [ 3273 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.022998 [ 8473 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:27.068325 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.438202 [ 3414 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.478976 [ 3322 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.479529 [ 3296 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.687067 [ 3307 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:27.775188 [ 7933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:27.931602 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.071271 [ 3472 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.154290 [ 7934 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:28.443971 [ 3316 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.484327 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.486513 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.547579 [ 7615 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:44672, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.599209 [ 7898 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37358, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.600661 [ 5600 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43320, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cbd19d 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb44bb 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.689068 [ 3037 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:28.814127 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:28.933385 [ 3305 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.103038 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.129398 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:29.447852 [ 3057 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.486225 [ 3236 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.491019 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.690828 [ 3017 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:29.700134 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:29.945081 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.034992 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:30.116675 [ 3172 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.449915 [ 3421 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.487843 [ 3018 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.492970 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.613743 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:30.696389 [ 3452 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.947278 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:30.954490 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:31.123548 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:31.453533 [ 3177 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:31.490331 [ 3330 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:31.494639 [ 3420 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:31.581168 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:31.698527 [ 3282 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:31.954638 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.087888 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:32.131469 [ 3464 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.456180 [ 3444 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.495613 [ 3383 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.496697 [ 3152 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.557862 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:32.709586 [ 3277 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:32.960240 [ 3163 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.086404 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:33.133603 [ 3442 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.458627 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.498097 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.498957 [ 3252 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.592788 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:33.712327 [ 3468 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:33.962652 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.104362 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:34.135473 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.453463 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:34.463679 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.500001 [ 3364 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.500865 [ 3016 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.717462 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:34.970463 [ 3320 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.138325 [ 3096 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.233101 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:35.456633 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:35.465315 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.501500 [ 3181 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.502245 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.719379 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:35.972409 [ 3345 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.140262 [ 3169 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.151984 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:36.332137 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:36.466971 [ 3090 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.503657 [ 3049 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.504254 [ 3333 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.723475 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:36.974181 [ 3449 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.037234 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:37.142189 [ 3482 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.205337 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:37.468604 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.505276 [ 3237 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.505826 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.725170 [ 3045 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:37.881143 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:37.975929 [ 3245 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.080690 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:38.225020 [ 3343 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.470244 [ 3419 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.506932 [ 3336 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.507224 [ 3232 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.727086 [ 3224 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.819555 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:38.915484 [ 5600 ] {6c212138-2228-4502-ba0b-eb7a6dbe0de1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55156) (comment: 01006_simpod_empty_part_single_column_write.sh) (in query: DROP DATABASE IF EXISTS test_9vr20a8y ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:38.938686 [ 5600 ] {6c212138-2228-4502-ba0b-eb7a6dbe0de1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:38.977913 [ 3234 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.007519 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:39.227474 [ 3266 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.472184 [ 3399 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.509664 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.509936 [ 2991 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.733779 [ 3293 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:39.873262 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:39.980891 [ 3187 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:40.070906 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:40.229800 [ 3326 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:40.474703 [ 3183 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:40.512719 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:40.514704 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:40.738281 [ 3132 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.006796 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.019468 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:41.036077 [ 5600 ] {7f685a15-3781-4409-b3d5-428db17be863} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55184) (comment: 01009_global_array_join_names.sql) (in query: DROP DATABASE IF EXISTS test_4gcpayni ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:41.051351 [ 5600 ] {7f685a15-3781-4409-b3d5-428db17be863} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.129887 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:41.239277 [ 3276 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.522762 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.523785 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.534560 [ 3113 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:41.740965 [ 3203 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.010550 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.176814 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:42.244922 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:42.246362 [ 3065 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.525290 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.526422 [ 3382 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.537367 [ 3335 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:42.746621 [ 3038 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.015747 [ 3145 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.250694 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:43.251886 [ 3472 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.316114 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:43.580420 [ 3227 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.580916 [ 3337 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.587696 [ 3146 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:43.749428 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.018533 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.254512 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.292899 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.373096 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.400362 [ 7615 ] {f179cbe5-a9c8-4814-b305-e918d257b93e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40580) (comment: 01925_map_populate_series_on_map.sql) (in query: select mapPopulateSeries(m, 10) from map_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.401820 [ 7615 ] {f179cbe5-a9c8-4814-b305-e918d257b93e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.491598 [ 7615 ] {cf9bcb7f-da1c-4d9b-83c7-b28f4334faf6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55234) (comment: 01925_map_populate_series_on_map.sql) (in query: DROP DATABASE IF EXISTS test_laiy7002 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.493210 [ 7615 ] {cf9bcb7f-da1c-4d9b-83c7-b28f4334faf6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.529492 [ 7898 ] {d666949e-a12a-418e-9692-9f95738b084d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55238) (comment: 01925_map_populate_series_on_map.sql) (in query: DROP DATABASE IF EXISTS test_laiy7002 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.531093 [ 7898 ] {d666949e-a12a-418e-9692-9f95738b084d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.573312 [ 7615 ] {5c08fb40-8270-40d3-afa7-c9c7ddf47cb9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55242) (comment: 01925_map_populate_series_on_map.sql) (in query: DROP DATABASE IF EXISTS test_laiy7002 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.575861 [ 7615 ] {5c08fb40-8270-40d3-afa7-c9c7ddf47cb9} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.582809 [ 3373 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.583423 [ 3311 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.589979 [ 3041 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.640174 [ 7898 ] {53344010-6f3a-449d-823b-af6168c2618b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55258) (comment: 01925_map_populate_series_on_map.sql) (in query: DROP DATABASE IF EXISTS test_laiy7002 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.641846 [ 7898 ] {53344010-6f3a-449d-823b-af6168c2618b} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.754700 [ 2976 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:44.755899 [ 7615 ] {87f68aef-ee84-45a7-ae48-4fd0485df8ed} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55266) (comment: 01925_map_populate_series_on_map.sql) (in query: DROP DATABASE IF EXISTS test_laiy7002 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:44.759848 [ 7615 ] {87f68aef-ee84-45a7-ae48-4fd0485df8ed} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.020828 [ 2998 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.258603 [ 3190 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.310590 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:45.413073 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:45.585026 [ 2969 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.591824 [ 3388 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.592433 [ 3215 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:45.759377 [ 3048 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.022679 [ 3401 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.174821 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:46.260411 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.269833 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:46.595203 [ 3258 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.596487 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.597375 [ 3013 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.606049 [ 7897 ] {0d47eeb1-c6e8-4c75-8438-048107027aee} 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.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37248) (comment: 02552_sparse_columns_intersect.sql) (in query: SELECT `__table1`.`a` AS `a` FROM `test_rjap6z4y`.`t_sparse_intersect` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:18:46.636348 [ 7897 ] {0d47eeb1-c6e8-4c75-8438-048107027aee} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:18:46.679483 [ 2929 ] {50632432-4761-4eb4-94fa-377a01cf7515} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40636) (comment: 02552_sparse_columns_intersect.sql) (in query: SELECT count() FROM (SELECT * FROM t_sparse_intersect INTERSECT SELECT * FROM t_sparse_intersect);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:18:46.750005 [ 7909 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40234, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:46.759603 [ 2929 ] {50632432-4761-4eb4-94fa-377a01cf7515} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:18:46.761291 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.025288 [ 3178 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.025189 [ 7615 ] {e73baff4-8eed-4365-8790-c8522a77152c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40564) (comment: 02552_sparse_columns_intersect.sql) (in query: DROP DATABASE IF EXISTS test_rjap6z4y ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:47.042505 [ 7615 ] {e73baff4-8eed-4365-8790-c8522a77152c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.171770 [ 7898 ] {8f2b1402-fbbe-4e3a-b4f4-f46bbead4334} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40572) (comment: 02552_sparse_columns_intersect.sql) (in query: DROP DATABASE IF EXISTS test_rjap6z4y ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:47.174181 [ 7898 ] {8f2b1402-fbbe-4e3a-b4f4-f46bbead4334} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.200526 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:47.209821 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:47.250810 [ 5600 ] {b800056a-6dd0-4592-ab01-c62e18dccd07} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:40582) (comment: 02552_sparse_columns_intersect.sql) (in query: DROP DATABASE IF EXISTS test_rjap6z4y ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:18:47.252474 [ 5600 ] {b800056a-6dd0-4592-ab01-c62e18dccd07} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.270735 [ 3120 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.599373 [ 3025 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.601046 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.601460 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.769233 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:47.773219 [ 7615 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.027795 [ 3384 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.236751 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:48.273142 [ 3123 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.314846 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:48.601834 [ 3446 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.615382 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.616224 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:48.771819 [ 3450 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.030637 [ 3306 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.275929 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.426481 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:49.548889 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:49.607492 [ 3262 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.621310 [ 3164 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.622561 [ 3411 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:49.774541 [ 3280 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.033499 [ 3092 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.278694 [ 3254 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.313256 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8f25176d-6bf0-484f-b27f-d635da64b3f4::202509_1_117_37}: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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() @ 0x0000000012aacaf9 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac0f1 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.533237 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:50.600890 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:50.612565 [ 3323 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.624848 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.683052 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:50.861858 [ 3310 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.036547 [ 3469 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.281609 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.616050 [ 3106 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.627423 [ 3373 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.656001 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:51.685764 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:51.712361 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:51.864744 [ 3390 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.038654 [ 3322 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.284184 [ 3182 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.619711 [ 3264 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.630072 [ 3099 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.688636 [ 3017 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.773510 [ 3595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_98_136_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.867630 [ 2975 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:52.906094 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:52.987987 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:53.041097 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:53.287561 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:53.626174 [ 3311 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:53.633271 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:53.691033 [ 3475 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:53.870494 [ 3417 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.044142 [ 3137 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.141414 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:54.200959 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:54.299050 [ 3120 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.629818 [ 2983 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.636366 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.693715 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:54.873568 [ 3064 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.046309 [ 3270 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.148898 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:55.150860 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:55.302489 [ 3103 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.632412 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.638993 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.697805 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:55.884358 [ 3231 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.019242 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:56.043897 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:56.054389 [ 3362 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.304906 [ 3209 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.637265 [ 2969 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.644011 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.706693 [ 3282 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:56.889549 [ 3072 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.039869 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:57.045786 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:57.056715 [ 3071 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.307745 [ 3213 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.639594 [ 3388 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.649171 [ 3408 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.709371 [ 3056 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:57.892171 [ 2993 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.059848 [ 3156 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.190481 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:58.209546 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:58.324460 [ 3007 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.641831 [ 3354 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.651710 [ 3285 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.712394 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:58.960745 [ 3121 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.063770 [ 3159 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.280141 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:59.330472 [ 3361 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.332042 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:18:59.671028 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.671385 [ 3013 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.714367 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:18:59.962995 [ 3320 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.066813 [ 3086 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.333482 [ 3396 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.458443 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:00.493605 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:00.674199 [ 3325 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.674603 [ 3240 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.716683 [ 3009 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:00.975883 [ 3411 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.069527 [ 3386 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.336170 [ 3239 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.505305 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:01.542103 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:01.676676 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.679806 [ 3091 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.719378 [ 3255 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:01.978368 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.072005 [ 3171 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.338845 [ 3340 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.470291 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:02.512882 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:02.679520 [ 3189 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.682320 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.721842 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:02.980829 [ 3031 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.074223 [ 3039 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.387252 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.417120 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:03.436167 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:03.681974 [ 3203 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.684702 [ 3203 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.737959 [ 3074 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:03.983383 [ 3217 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.076870 [ 3077 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.389678 [ 3392 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.556541 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:04.617072 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:04.684590 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.689885 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.743838 [ 3193 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:04.987005 [ 2996 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.079378 [ 3464 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.392198 [ 3377 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.615469 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:05.637997 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:05.687358 [ 2965 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.692486 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.746403 [ 3093 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:05.989339 [ 3273 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.082146 [ 3288 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.394395 [ 3105 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.689673 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.694978 [ 3426 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.748870 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:06.779478 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:06.824406 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:06.991026 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.084968 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.407569 [ 3315 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.692209 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.697301 [ 3422 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.751384 [ 3085 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:07.778440 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:07.822425 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:07.993104 [ 3101 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.183358 [ 3169 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.410230 [ 3419 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.695652 [ 3063 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.713234 [ 3222 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.758042 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:08.818261 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:08.991790 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:08.995362 [ 3433 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.189814 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.412124 [ 3330 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.702772 [ 3188 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.716360 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.760715 [ 3079 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:09.885638 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:10.000732 [ 3186 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.013453 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:10.192836 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.414948 [ 3268 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.707482 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.718417 [ 3308 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.762804 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:10.795586 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:10.884276 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:11.002726 [ 3021 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.194929 [ 3323 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.416977 [ 2991 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.709769 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.725185 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.764819 [ 3084 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:11.842002 [ 73287 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:11.914154 [ 73290 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.005042 [ 3471 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.100609 [ 7615 ] {a95c452e-602b-4a66-b5ce-1a39bcf43ee7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=16). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:37390) (comment: 00632_get_sample_block_cache.sql) (in query: SELECT count() FROM ( SELECT x, count() AS c FROM ( SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) UNION ALL SELECT * FROM ( SELECT * FROM sample_00632 WHERE x > 0 ) ) GROUP BY x --HAVING c = 1 ORDER BY x 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.196820 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.332424 [ 73284 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43182, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.333514 [ 7909 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43168, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.338101 [ 7897 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54034, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.344516 [ 73283 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52192, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.345931 [ 5300 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34662, local: [::ffff:127.0.0.10]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.350743 [ 4665 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34356, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.357472 [ 5600 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52190, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.361027 [ 7604 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43418, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.364927 [ 2929 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59416, local: [::ffff:127.0.0.9]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.369113 [ 4905 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:53246, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.370437 [ 8202 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48850, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.419557 [ 3191 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.588418 [ 7615 ] {a95c452e-602b-4a66-b5ce-1a39bcf43ee7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=16). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60bc5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.766659 [ 2929 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.766741 [ 3376 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.767430 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.799068 [ 5600 ] {d6514bda-24b1-4a3b-bfee-0d7c7c9e2845} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56058) (comment: 00632_get_sample_block_cache.sql) (in query: DROP DATABASE IF EXISTS test_ju2n9unv ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.802605 [ 5600 ] {d6514bda-24b1-4a3b-bfee-0d7c7c9e2845} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.818885 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:12.903379 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.950943 [ 2929 ] {413bd62e-2d9f-4f4f-b89b-8e1681d4ef99} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:56066) (comment: 00632_get_sample_block_cache.sql) (in query: DROP DATABASE IF EXISTS test_ju2n9unv ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:19:12.953339 [ 2929 ] {413bd62e-2d9f-4f4f-b89b-8e1681d4ef99} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.010069 [ 3275 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.199516 [ 3324 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.426428 [ 3318 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.649558 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:13.773493 [ 3198 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.774676 [ 3067 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:13.792282 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:13.821737 [ 3332 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.012825 [ 3104 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.203198 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.428144 [ 3157 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.561543 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:14.655347 [ 2929 ] {ba8e771a-1558-42be-855c-2e180aa78ffa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33906) (comment: 00575_merge_and_index_with_function_in_in.sql) (in query: select count() from t_00575 where toDayOfWeek(d) in (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:19:14.660703 [ 2929 ] {ba8e771a-1558-42be-855c-2e180aa78ffa} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:19:14.660939 [ 7932 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37656, local: [::ffff:127.0.0.8]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.683522 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:14.776183 [ 2964 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.777872 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:14.824391 [ 3359 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.015451 [ 3145 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.215302 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.430548 [ 3371 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.690887 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:15.778918 [ 3038 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.786523 [ 3470 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.827940 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:15.840091 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:16.017818 [ 3284 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.221218 [ 3443 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.530133 [ 3192 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.675932 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:16.784690 [ 2974 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.788786 [ 3127 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.832460 [ 3025 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:16.859870 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:17.020044 [ 2998 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:17.226552 [ 3295 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:17.532478 [ 3248 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:17.603638 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:17.786418 [ 3074 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:17.790487 [ 3241 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:17.800295 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:17.836146 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.022142 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.229681 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.534716 [ 3237 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.567628 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:18.788638 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.792351 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.838439 [ 3347 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:18.864327 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:19.024370 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.235574 [ 3276 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.537518 [ 3268 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.653884 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:19.792085 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.794975 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.841688 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:19.947587 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:20.026842 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.241537 [ 3418 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.539669 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:20.540059 [ 3232 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.794228 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.797795 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.844057 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:20.920802 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:21.029246 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.244478 [ 3206 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.450785 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:21.545116 [ 3061 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.796030 [ 3201 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.799558 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.845844 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:21.874409 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:22.031249 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:22.246366 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:22.370600 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:22.546655 [ 3382 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:22.798171 [ 3480 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:22.800141 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:22.801560 [ 3310 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:22.848121 [ 2975 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.033140 [ 3027 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.248666 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.330473 [ 5600 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:23.548477 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.766248 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:23.803778 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.804843 [ 3243 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:23.850193 [ 3225 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.035545 [ 3071 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.250546 [ 3406 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.285551 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:24.550537 [ 3335 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.764268 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:24.805627 [ 3051 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.806628 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:24.852248 [ 3247 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.037483 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.218377 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:25.254839 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.554862 [ 3227 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.699923 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:25.807551 [ 3446 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.808490 [ 3456 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:25.857446 [ 3135 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.039517 [ 3386 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.171924 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:26.260028 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.557101 [ 3122 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.684564 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:26.810101 [ 2985 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.810835 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:26.859915 [ 3028 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.041348 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.147376 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:27.264282 [ 3110 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.566034 [ 3360 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.586662 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:27.812834 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.813834 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.864167 [ 3143 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:27.993745 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:28.043345 [ 3053 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.266396 [ 3316 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.563651 [ 7909 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:28.570873 [ 3388 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.815087 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.816219 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.866110 [ 3342 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:28.961902 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:29.045090 [ 3014 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.272749 [ 3477 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.466965 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:29.572870 [ 3285 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.813403 [ 7897 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:29.817911 [ 3218 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.818949 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.875713 [ 3164 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.877190 [ 8473 ] {527deca0-1bbe-41fd-97b1-30e5af4e0ddd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34370) (comment: 02835_parallel_replicas_over_distributed.sql) (in query: DROP DATABASE IF EXISTS test_uquf0396 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:19:29.878758 [ 8473 ] {527deca0-1bbe-41fd-97b1-30e5af4e0ddd} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:29.947299 [ 7897 ] {6741ceac-4b58-4e62-9337-f278199f7dde} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60686) (comment: 02835_parallel_replicas_over_distributed.sql) (in query: DROP DATABASE IF EXISTS test_uquf0396 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:19:29.963537 [ 7897 ] {6741ceac-4b58-4e62-9337-f278199f7dde} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.046792 [ 3108 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.281022 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.396308 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:30.581407 [ 3166 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.736864 [ 7615 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:30.820342 [ 3245 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.821471 [ 3031 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:30.877721 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.053497 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.283179 [ 3308 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.443472 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:31.583426 [ 3325 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.724222 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:31.822424 [ 3385 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.823424 [ 3297 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:31.880193 [ 3184 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.055874 [ 3428 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.290137 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.416530 [ 7909 ] {b2e9b0a2-8104-47ed-a469-e1500b483ce4} executeQuery: Code: 252. DB::Exception: Too many parts (10) in all partitions in total in table 'test_effiq5n3.max_parts_in_total (ecb8ffcc-1812-45d4-b399-cf4c6e101bb7)'. This indicates wrong choice of partition key. The threshold can be modified with 'max_parts_in_total' setting in element in config.xml or with per-table setting. (TOO_MANY_PARTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41498) (comment: 00940_max_parts_in_total.sql) (in query: INSERT INTO max_parts_in_total SELECT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&, String&&) @ 0x0000000008a8f28b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba8b0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 12. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:19:32.420067 [ 7909 ] {b2e9b0a2-8104-47ed-a469-e1500b483ce4} TCPHandler: Code: 252. DB::Exception: Too many parts (10) in all partitions in total in table 'test_effiq5n3.max_parts_in_total (ecb8ffcc-1812-45d4-b399-cf4c6e101bb7)'. This indicates wrong choice of partition key. The threshold can be modified with 'max_parts_in_total' setting in element in config.xml or with per-table setting. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&, String&&) @ 0x0000000008a8f28b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x00000000127ba8b0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012faca1d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 8. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 12. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:19:32.573514 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:32.586054 [ 2968 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.824248 [ 3229 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.824740 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:32.876846 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:32.889197 [ 3278 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.058900 [ 3338 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.292967 [ 3269 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.589094 [ 3122 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.819055 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:33.884197 [ 3051 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.887578 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:33.891249 [ 3070 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.017168 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:34.070633 [ 3141 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.295771 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.637953 [ 3081 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.889374 [ 3080 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.894637 [ 2993 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:34.896218 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.004270 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:35.073841 [ 3346 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.138087 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:35.305062 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.640934 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.892446 [ 3446 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.906313 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:35.987382 [ 3031 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.079595 [ 3370 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.198525 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:36.307754 [ 3196 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.383297 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:36.644005 [ 3215 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.894958 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.908952 [ 3397 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:36.989809 [ 3187 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.082141 [ 3205 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.309471 [ 3213 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.345582 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:37.484120 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:37.645785 [ 3119 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.861034 [ 8202 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.896708 [ 2985 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.910905 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:37.992009 [ 3385 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.083956 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.311833 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.357573 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:38.421726 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:38.652306 [ 3283 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.898204 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.914359 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:38.995487 [ 3297 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.090322 [ 3133 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.314066 [ 2968 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.323670 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:39.368954 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:39.654135 [ 3459 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.967420 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.970751 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:39.999708 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:40.094681 [ 3044 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:40.222488 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:40.291851 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:40.315973 [ 3094 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:40.656508 [ 3001 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:40.968941 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:40.972618 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.001794 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.101502 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.318735 [ 3007 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.418220 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:41.471955 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:41.658648 [ 2995 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.971672 [ 2996 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:41.978068 [ 3216 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.010456 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.104349 [ 3053 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.322114 [ 3396 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.487154 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:42.567846 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:42.660831 [ 3166 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.974130 [ 3273 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:42.980222 [ 3274 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.013353 [ 3433 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.106577 [ 3288 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.324568 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.523729 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:43.663247 [ 3013 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.666926 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:43.976553 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:43.982298 [ 3125 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.014980 [ 3145 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.109023 [ 3134 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.328552 [ 3327 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.574366 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:44.666509 [ 3185 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.718009 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:44.978480 [ 3275 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:44.984475 [ 3101 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.109295 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.187183 [ 3263 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.330775 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.545131 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:45.672565 [ 3195 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.741327 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:45.984192 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:45.990439 [ 2998 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.111670 [ 3066 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.249023 [ 3467 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.333373 [ 3003 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.524082 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:46.666840 [ 4299 ] {f2bb5dc1-731f-4d61-838a-409b593e850a} PushingToViews: Cannot push to the storage, ignoring the error: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.A, 1_UInt8) :: 1) -> throwIf(equals(__table1.A, 1_UInt8)) UInt8 : 0': while pushing to view test_4fme4lgx.testXB (b97788c4-44cd-4c34-b8ae-3299335c8a5b). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x0000000011197afd 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 15. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 17. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001305a0e5 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad29e 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facca1 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 26. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.675394 [ 3475 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.711181 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:46.988260 [ 3401 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:46.993188 [ 3328 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:47.113782 [ 3323 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:47.251942 [ 3314 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:47.336077 [ 3394 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:47.667842 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:47.677018 [ 3447 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:47.882424 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:47.991618 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.007860 [ 3315 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.115991 [ 3448 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.254545 [ 3139 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.338785 [ 3339 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.683788 [ 3487 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:48.714409 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:48.993687 [ 2974 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.010214 [ 3127 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.015424 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:49.118061 [ 3093 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.260200 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.341415 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.686100 [ 3017 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:49.807764 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:49.996301 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.013182 [ 3433 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.120953 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.189018 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:50.262843 [ 3082 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.344073 [ 3030 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.690969 [ 3475 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:50.872856 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:51.000616 [ 3184 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.015718 [ 3104 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.123135 [ 3350 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.268792 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.277058 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:51.348185 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.696783 [ 3366 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:51.921579 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:52.003567 [ 3352 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:52.018475 [ 3145 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:52.134407 [ 3391 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:52.271886 [ 3453 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:52.353788 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:52.513298 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:52.699712 [ 3282 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.012013 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.025282 [ 3321 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.139219 [ 3435 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.161888 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:53.284416 [ 3069 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.357133 [ 3238 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:53.680805 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:53.702361 [ 3124 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.014111 [ 3401 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.027238 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.142225 [ 3014 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.282365 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:54.295755 [ 3477 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.360256 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.705220 [ 3056 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:54.717859 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:55.016111 [ 3322 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.031616 [ 3296 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.145961 [ 3134 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.297812 [ 3037 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.311072 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:55.369726 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.707775 [ 3240 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:55.747242 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:56.026270 [ 3328 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:56.033280 [ 3137 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:56.147534 [ 3162 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:56.271877 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:56.309457 [ 2968 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:56.371438 [ 3058 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:56.673338 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:56.715678 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.027957 [ 3478 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.119839 [ 3027 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.149136 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.183210 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:57.322129 [ 3007 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.373266 [ 3200 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:57.601884 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:57.723377 [ 3293 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.030262 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.122165 [ 3053 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.151557 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.249664 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:58.323728 [ 3361 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.375411 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:58.667553 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:58.727076 [ 3091 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.032996 [ 3086 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.124965 [ 3288 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.157695 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.329000 [ 3015 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.378096 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.384428 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:19:59.729670 [ 3167 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:19:59.862578 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:00.035869 [ 3044 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.130043 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.160401 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.331869 [ 3431 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.380623 [ 3032 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.509083 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:00.589385 [ 4665 ] {820c1f3c-f3c0-48bf-b066-8674b352143e} 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.10508.altinitytest (altinity build)) (from [::1]:41552) (comment: 01275_parallel_mv.gen.sql) (in query: select peak_threads_usage from system.query_log where current_database = currentDatabase() and type != 'QueryStart' and query like '%insert into testX %' and Settings['parallel_view_processing'] = '0' and Settings['optimize_trivial_insert_select'] = '0' and Settings['max_insert_threads'] = '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:20:00.609205 [ 4665 ] {820c1f3c-f3c0-48bf-b066-8674b352143e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:20:00.731254 [ 3260 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:00.929509 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:01.038251 [ 3140 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.137643 [ 3206 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.166474 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.334349 [ 3131 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.384451 [ 3432 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.637402 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:01.733504 [ 2964 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:01.962172 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:02.043369 [ 3356 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.141620 [ 3405 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.169039 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.336156 [ 3208 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.386382 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.569138 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:02.736095 [ 3038 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:02.938883 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:03.052480 [ 3291 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.144377 [ 3299 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.170907 [ 2991 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.338055 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.388901 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.573406 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:03.737928 [ 3048 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:03.898724 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:04.055023 [ 3488 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.151088 [ 3227 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.173529 [ 3155 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.340296 [ 3287 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.391483 [ 3271 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.516016 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:04.808564 [ 3093 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:04.815981 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:05.060314 [ 3013 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.153731 [ 3185 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.191629 [ 3325 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.342794 [ 3437 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.394190 [ 3231 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.550102 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:05.811701 [ 3348 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:05.931168 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:06.067432 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.156653 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.194434 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.373175 [ 3342 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.396940 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.563076 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:06.814155 [ 3125 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:06.906953 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:07.069736 [ 3141 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.159567 [ 3108 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.200231 [ 3076 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.376506 [ 3394 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.406429 [ 3380 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.434363 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:07.816562 [ 3033 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:07.984254 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:08.071968 [ 3346 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.202284 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.220852 [ 3369 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.308049 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:08.381111 [ 3344 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.408347 [ 3409 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.820421 [ 3359 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:08.895218 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:09.073633 [ 3159 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.164180 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:09.205288 [ 3263 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.222919 [ 3266 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.388485 [ 3355 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.411468 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.827635 [ 2988 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:09.846674 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:10.075298 [ 3160 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.135492 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:10.207119 [ 3393 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.283265 [ 3428 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.390668 [ 3416 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.413676 [ 3302 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.832880 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:10.889349 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:11.077006 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.086701 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:11.208909 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.285080 [ 3078 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.392844 [ 3228 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.416744 [ 3194 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.837600 [ 3088 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:11.909323 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:11.967871 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:12.079255 [ 3205 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:12.211832 [ 3443 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:12.287374 [ 3120 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:12.397072 [ 3432 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:12.418809 [ 3191 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:12.819836 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:12.829841 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:12.842352 [ 3353 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.081276 [ 3000 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.213380 [ 3204 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.289568 [ 3387 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.400779 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.420785 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:13.688121 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:13.709663 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:13.844215 [ 3153 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.082983 [ 3086 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.235146 [ 3276 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.294338 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.402954 [ 3392 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.422988 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:14.665099 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:14.796612 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:14.846282 [ 3480 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.085369 [ 3386 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.238222 [ 3066 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.297136 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.408084 [ 2966 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.425187 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.844031 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:15.851027 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:15.885577 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:16.087523 [ 3171 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.245507 [ 3107 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.300193 [ 3103 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.410841 [ 3042 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.427770 [ 3250 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.882191 [ 3454 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:16.885987 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:17.060917 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:17.089831 [ 3133 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:17.252257 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:17.303330 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:17.416296 [ 3444 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:17.434905 [ 3402 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:17.884434 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:17.884575 [ 3247 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.092450 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.143710 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:18.254822 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.306051 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.418677 [ 3315 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.437755 [ 3223 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:18.887673 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.071339 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:19.159760 [ 3312 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.257622 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.309282 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:19.312874 [ 3254 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.440958 [ 3090 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.471893 [ 3029 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.889730 [ 2993 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:19.988023 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:20.161943 [ 3211 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:20.186922 [ 7604 ] {26c83cfd-4159-4907-b704-2ed7d1def394} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42008) (comment: 01866_bit_positions_to_array.sql) (in query: SELECT '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:20:20.196864 [ 7604 ] {26c83cfd-4159-4907-b704-2ed7d1def394} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:20:20.263771 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:20.276937 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:20.317801 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:20.443056 [ 3202 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:20.473893 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:20.895479 [ 3446 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.028027 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:21.165956 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.269566 [ 3361 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.317275 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:21.323751 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.445283 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.478586 [ 3083 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.898504 [ 3456 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:21.968131 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:22.171655 [ 3131 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:22.271552 [ 3327 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:22.326227 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:22.406932 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:22.448482 [ 3181 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:22.481159 [ 3050 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:22.912573 [ 3011 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.015143 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:23.173888 [ 3238 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.277703 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.329446 [ 3220 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.349855 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:23.451150 [ 3378 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.484101 [ 3034 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:23.952112 [ 3012 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.128846 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:24.227611 [ 3257 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.280662 [ 3200 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.335262 [ 3309 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.432142 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:24.455944 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.486687 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:24.954306 [ 3059 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.222808 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:25.230005 [ 3095 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.283708 [ 3382 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.338059 [ 3335 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.461907 [ 3146 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.492186 [ 3154 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.668453 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:25.805828 [ 3589 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1aef7ea7-cbf0-4db2-93e7-d853aa133566::202509_1_137_48}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:25.961529 [ 3138 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.235845 [ 3440 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.285988 [ 3023 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.343631 [ 3166 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.464597 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.494678 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:26.518157 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:26.916140 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:26.964040 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.239572 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.289805 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.348184 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.476537 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.497038 [ 3319 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:27.516880 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:27.904463 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:27.966026 [ 3245 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.241107 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.291755 [ 2998 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.350458 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.480960 [ 3328 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.515676 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.560059 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:28.823997 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:28.837679 [ 7604 ] {cb89f424-a5ff-41ff-96db-3a01145384ac} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46900) (comment: 03093_analyzer_miel_test.sql) (in query: DROP DATABASE IF EXISTS test_ep19nnqa ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:20:28.864292 [ 7604 ] {cb89f424-a5ff-41ff-96db-3a01145384ac} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.907484 [ 4905 ] {0404b581-d328-4461-a6c6-e7e5580f1f89} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:46912) (comment: 03093_analyzer_miel_test.sql) (in query: DROP DATABASE IF EXISTS test_ep19nnqa ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:20:28.909229 [ 4905 ] {0404b581-d328-4461-a6c6-e7e5580f1f89} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:28.968188 [ 3164 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.026078 [ 7604 ] {84ed140b-fdf8-443a-8715-f3c81d1ca874} 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.10508.altinitytest (altinity build)) (from [::1]:46916) (comment: 03093_analyzer_miel_test.sql) (in query: DROP DATABASE IF EXISTS test_ep19nnqa ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:20:29.027734 [ 7604 ] {84ed140b-fdf8-443a-8715-f3c81d1ca874} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.244592 [ 3455 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.303796 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.352763 [ 3165 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.451243 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:29.485045 [ 3441 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.518048 [ 3252 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:29.744327 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:29.970234 [ 3345 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.246332 [ 3472 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.306936 [ 3196 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.346877 [ 4905 ] {1e079528-7066-4280-be2a-d7392fc963d8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51450) (comment: 01660_second_extremes_bug.sql) (in query: DROP TABLE IF EXISTS t_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:30.358356 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.363385 [ 4905 ] {1e079528-7066-4280-be2a-d7392fc963d8} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:30.394359 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:30.487119 [ 3236 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.520038 [ 3364 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:30.757519 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:30.972432 [ 3449 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.248993 [ 3092 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.361118 [ 3314 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.395053 [ 3213 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.491800 [ 3202 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.492263 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:31.524023 [ 3466 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:31.879307 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:31.975815 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.260063 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.363793 [ 3199 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.397146 [ 3380 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.494462 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.535739 [ 3052 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:32.547070 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:32.931458 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:32.978278 [ 3031 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.262386 [ 3257 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.368190 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.431425 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.496708 [ 3152 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.538072 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:33.577850 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:33.896311 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:33.980698 [ 3483 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.264308 [ 3453 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.370916 [ 3344 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.434778 [ 3060 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.499617 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.541160 [ 3299 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:34.543040 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:34.956301 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:34.989740 [ 3303 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.266650 [ 3294 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.373489 [ 3334 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.437114 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.506306 [ 2992 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.546866 [ 3061 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:35.599301 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:35.956494 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:35.992163 [ 3273 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.271670 [ 3190 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.378981 [ 3118 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.440767 [ 3042 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.508135 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.548981 [ 2991 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:36.551341 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:36.963787 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:36.993950 [ 3473 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.273862 [ 3078 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.382857 [ 3392 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.444980 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.463912 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:37.509765 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.550580 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.953217 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:37.965410 [ 5300 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:37.997836 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.276151 [ 3120 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.384924 [ 3157 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.390562 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:38.455443 [ 3402 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.511823 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.552613 [ 3471 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:38.743322 [ 3590 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1f5dde2e-b2d7-4e9d-9554-6a73596d18e1::202509_201_241_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.000174 [ 3114 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.028417 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:39.278753 [ 3123 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.392422 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.421533 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:39.460048 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.514390 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:39.554848 [ 3488 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.005220 [ 3280 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.086940 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:40.281795 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.394706 [ 3448 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.452371 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:40.462615 [ 3357 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.520061 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.557172 [ 3119 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:40.627152 [ 3589 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {06e0dcf3-6e7a-4ddb-850b-40d5fef4d059::202509_1_141_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.008030 [ 3125 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.101286 [ 7604 ] {5a47b8a5-0242-489b-93cf-47fec7a0173a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51496) (comment: 01781_token_extractor_buffer_overflow.sql) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000012870f43 11. /build/contrib/llvm-project/libcxx/include/deque:1188: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000001285764b 12. /build/contrib/llvm-project/libcxx/include/deque:2969: 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)::$_0::operator()(unsigned long) const @ 0x0000000012855eb4 13. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl, 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x000000001285b1d7 14. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 15. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 16. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:20:41.125473 [ 7604 ] {5a47b8a5-0242-489b-93cf-47fec7a0173a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000012870f43 11. /build/contrib/llvm-project/libcxx/include/deque:1188: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000001285764b 12. /build/contrib/llvm-project/libcxx/include/deque:2969: 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)::$_0::operator()(unsigned long) const @ 0x0000000012855eb4 13. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl, 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)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x000000001285b1d7 14. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 15. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 16. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:20:41.284597 [ 3431 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.397518 [ 3097 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.421430 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:41.465226 [ 3013 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.528971 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.561381 [ 3195 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.566898 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1aef7ea7-cbf0-4db2-93e7-d853aa133566::202509_1_139_50}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:41.603731 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:41.620877 [ 12607 ] {} test_vccglphd.bloom_filter (f9afa78d-963b-4129-aa46-80ecfda12ffa): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.25 21:20:41.645529 [ 12607 ] {} DatabaseCatalog: Cannot drop table test_vccglphd.bloom_filter (f9afa78d-963b-4129-aa46-80ecfda12ffa). Will retry later.: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001279a883 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>*) @ 0x00000000127988a0 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000001279e5f4 11. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000111829ee 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*) @ 0x000000001118a751 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010404c1a 14. /build/contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x000000000cba7437 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. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.011994 [ 3101 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.289123 [ 3193 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.405034 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.455937 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:42.467326 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.500069 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:42.531818 [ 3231 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:42.566218 [ 3012 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.014427 [ 3104 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.297143 [ 3145 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.407580 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.469757 [ 3108 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.534225 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.568960 [ 3312 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:43.594843 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:43.643594 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:44.025236 [ 3284 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.300375 [ 3103 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.410260 [ 3019 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.472857 [ 3419 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.536810 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.572262 [ 3113 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:44.709509 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:44.736794 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:45.028228 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.303541 [ 3209 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.415926 [ 3194 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.486555 [ 3022 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.539698 [ 3052 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.580976 [ 3471 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:45.792023 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:45.806422 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:46.033973 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.306084 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.419158 [ 3105 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.557883 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.559008 [ 3179 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.583154 [ 3227 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:46.732380 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:46.968095 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:47.084120 [ 3159 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.308128 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.421866 [ 3318 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.564270 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.565157 [ 3279 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.585703 [ 3122 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:47.875406 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:48.110476 [ 3172 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.171774 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:48.310923 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.424464 [ 3489 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.567995 [ 3117 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.570757 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.591802 [ 3149 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:48.878587 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:49.112684 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.305263 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:49.313564 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.427259 [ 3073 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.571041 [ 2982 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.578234 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.596450 [ 3020 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:49.919718 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:50.122519 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:50.263558 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:50.316848 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:50.429874 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:50.578039 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:50.585087 [ 3335 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:50.599463 [ 3146 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.080449 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:51.135892 [ 3391 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.237297 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:51.324796 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.432260 [ 3244 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.532061 [ 4905 ] {d199017c-1135-4a39-b0bd-fb0a08895e2f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59606) (comment: 00508_materialized_view_to.sql) (in query: DROP DATABASE test_vu1w0d19), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:51.534289 [ 4905 ] {d199017c-1135-4a39-b0bd-fb0a08895e2f} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:51.583513 [ 3281 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.586968 [ 3337 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.601658 [ 3008 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:51.666014 [ 5300 ] {c07f6ed4-b11c-4fa7-8053-de51dd9f2251} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50508) (comment: 00508_materialized_view_to.sql) (in query: DROP DATABASE IF EXISTS test_vu1w0d19 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:20:51.668765 [ 5300 ] {c07f6ed4-b11c-4fa7-8053-de51dd9f2251} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.123481 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:52.138832 [ 3096 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.319416 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:52.326786 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.438123 [ 3221 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.585558 [ 3106 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.589201 [ 3400 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:52.603715 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.141354 [ 3169 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.292773 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:53.329438 [ 3340 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.445464 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.452283 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:53.588170 [ 3373 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.594441 [ 3373 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:53.611537 [ 3311 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.143386 [ 3343 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.341705 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:54.342678 [ 3278 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.421664 [ 5300 ] {a3c910f0-71ce-4de3-aa51-ac1c3231e64a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59678) (comment: 00508_materialized_view_to.sql) (in query: DROP TABLE test_oxrmn5ra.src), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:54.430663 [ 5300 ] {a3c910f0-71ce-4de3-aa51-ac1c3231e64a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:54.448580 [ 3402 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.494189 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:54.590462 [ 2967 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.597280 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.613480 [ 5300 ] {85e822aa-27a9-45ec-b6da-ee0dbc9075dd} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50530) (comment: 00508_materialized_view_to.sql) (in query: DROP DATABASE IF EXISTS test_oxrmn5ra ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:20:54.613704 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:54.616527 [ 5300 ] {85e822aa-27a9-45ec-b6da-ee0dbc9075dd} DynamicQueryHandler: 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x00000000102e443a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572d4f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574fad 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.145927 [ 3014 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.345100 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.458655 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.475826 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:55.595896 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.599628 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.615955 [ 3388 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:55.657711 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:56.149075 [ 3134 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.374357 [ 3043 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.464855 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.542665 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:56.597991 [ 3354 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.606754 [ 3119 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.619352 [ 3408 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:56.703260 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:57.152092 [ 3108 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.376954 [ 3200 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.468056 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.600115 [ 3459 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.612902 [ 2995 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.621648 [ 3458 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:57.651497 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:57.764270 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:58.154068 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.382778 [ 3207 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.470319 [ 3183 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.603952 [ 3358 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.615026 [ 3166 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.624107 [ 3013 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:58.658547 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:58.801631 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:20:59.157229 [ 3109 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.385086 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.472929 [ 3410 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.606544 [ 3325 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.618009 [ 3468 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.629571 [ 3451 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:20:59.864393 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:00.096375 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:00.159707 [ 3263 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.387706 [ 3118 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.476396 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.609515 [ 3260 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.620880 [ 3038 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.632061 [ 2974 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:00.935608 [ 8202 ] {ff384ad3-c1cb-43c1-99df-82b6014683a1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:55522) (comment: 01275_parallel_mv.gen.sql) (in query: DROP DATABASE IF EXISTS test_4fme4lgx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:00.960482 [ 8202 ] {ff384ad3-c1cb-43c1-99df-82b6014683a1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.120354 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:01.168768 [ 3307 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.382163 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:01.390255 [ 3377 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.420216 [ 4665 ] {eba91557-1c6c-49fd-ac70-96caf9163831} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43478) (comment: 01275_parallel_mv.gen.sql) (in query: DROP DATABASE IF EXISTS test_4fme4lgx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:01.442785 [ 4665 ] {eba91557-1c6c-49fd-ac70-96caf9163831} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.481020 [ 3147 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.612540 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.625451 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.634623 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:01.891604 [ 5300 ] {e0b73015-c475-4a2b-b765-ae3eaf980183} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43488) (comment: 01275_parallel_mv.gen.sql) (in query: DROP DATABASE IF EXISTS test_4fme4lgx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:01.894117 [ 5300 ] {e0b73015-c475-4a2b-b765-ae3eaf980183} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.128975 [ 8202 ] {c8b8c34b-7711-4c0e-a186-f84e5a8f1905} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43502) (comment: 01275_parallel_mv.gen.sql) (in query: DROP DATABASE IF EXISTS test_4fme4lgx ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:02.136096 [ 8202 ] {c8b8c34b-7711-4c0e-a186-f84e5a8f1905} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.170674 [ 3276 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.392781 [ 3448 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.466204 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:02.467609 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:02.483449 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.614908 [ 3476 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.627964 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:02.640062 [ 3429 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.174735 [ 3246 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.395507 [ 3063 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.486094 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.617217 [ 2997 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.630024 [ 3188 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.637681 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:03.642608 [ 3138 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:03.669074 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:04.177259 [ 3356 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.399631 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.513136 [ 3236 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.620131 [ 3264 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.632308 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.649519 [ 3287 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:04.835313 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:04.876151 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.082557 [ 5300 ] {6a678e60-dc75-4a65-a88a-28b60d16be79} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44186) (comment: 01033_function_substring.sql) (in query: SELECT substring('hello', []);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b673735 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.085304 [ 5300 ] {6a678e60-dc75-4a65-a88a-28b60d16be79} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b673735 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.179543 [ 2979 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.331647 [ 5300 ] {ddf8975c-b061-4544-a4c5-1b626f773cd9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44186) (comment: 01033_function_substring.sql) (in query: SELECT substring('hello', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b673862 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.334728 [ 5300 ] {ddf8975c-b061-4544-a4c5-1b626f773cd9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b673862 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&) @ 0x00000000110501ab 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 29. ? @ 0x00007fd96814bac3 30. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.401673 [ 3432 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.537100 [ 3252 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.537168 [ 4905 ] {11827eb9-5e7f-4af3-ba43-1a21698c0c7e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43548) (comment: 01137_order_by_func_final.sql) (in query: DROP DATABASE IF EXISTS test_pnkm9cbf ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.539815 [ 4905 ] {11827eb9-5e7f-4af3-ba43-1a21698c0c7e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.622644 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.634806 [ 3081 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.652973 [ 3271 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.699248 [ 5300 ] {5c0e378d-c7c5-419e-b6cf-97f38adb3cfd} executeQuery: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44186) (comment: 01033_function_substring.sql) (in query: SELECT substring(materialize('hello'), 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b672bf9 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::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcb9e1 11. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 15. /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>>&) @ 0x0000000011654afc 16. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 17. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 18. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 19. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.706638 [ 5300 ] {5c0e378d-c7c5-419e-b6cf-97f38adb3cfd} TCPHandler: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/substring.cpp:0: DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b672bf9 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::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcb9e1 11. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 15. /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>>&) @ 0x0000000011654afc 16. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 17. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 18. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 19. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.708332 [ 7604 ] {ba68a8ba-381d-426e-8d76-b8145e5e8422} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43564) (comment: 01137_order_by_func_final.sql) (in query: DROP DATABASE IF EXISTS test_pnkm9cbf ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.727254 [ 7604 ] {ba68a8ba-381d-426e-8d76-b8145e5e8422} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:05.861603 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:05.909421 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:06.181356 [ 3109 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.409121 [ 3151 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.539130 [ 3331 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.624979 [ 3311 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.641581 [ 3375 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.655504 [ 3459 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:06.822114 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:06.846526 [ 4905 ] {b8123bf5-35d3-4773-afc1-02837306a2a1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44220) (comment: 02407_array_element_from_map_wrong_type.sql) (in query: select m[0], materialize(map('key', 42)) as 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/arrayElement.cpp:0: DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08e9bc 5. /build/src/Functions/array/arrayElement.cpp:0: DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08af82 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) @ 0x0000000010fcb9e1 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:21:06.848828 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:06.849012 [ 4905 ] {b8123bf5-35d3-4773-afc1-02837306a2a1} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/arrayElement.cpp:0: DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08e9bc 5. /build/src/Functions/array/arrayElement.cpp:0: DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c08af82 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) @ 0x0000000010fcb9e1 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:21:07.183306 [ 3351 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.410873 [ 3302 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.541086 [ 3268 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.626768 [ 2983 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.645283 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.658359 [ 3413 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:07.692066 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:07.759301 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:08.186825 [ 3076 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.422145 [ 3318 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.542797 [ 3232 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.628574 [ 2967 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.639562 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:08.647502 [ 3408 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.660210 [ 2995 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:08.694886 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:09.189282 [ 3324 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.423565 [ 3489 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.544579 [ 3148 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.630621 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.631813 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:09.652823 [ 3001 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.662408 [ 3458 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:09.733077 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:10.214328 [ 3317 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.425399 [ 3157 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.546620 [ 3299 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.563407 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:10.609281 [ 5300 ] {d1c5d171-f1bc-41e8-ae5c-cdb7f595ebe1} executeQuery: Code: 57. DB::Exception: Table test_gj29jq23.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:44186) (comment: 01033_function_substring.sql) (in query: CREATE TABLE tab (s String, l Int8, r Int8) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:21:10.629005 [ 5300 ] {d1c5d171-f1bc-41e8-ae5c-cdb7f595ebe1} TCPHandler: Code: 57. DB::Exception: Table test_gj29jq23.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:21:10.636243 [ 3360 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.654988 [ 3440 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.665017 [ 3097 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:10.697647 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:11.263343 [ 3082 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.427772 [ 3073 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.549254 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.639007 [ 2989 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.660742 [ 3023 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.667751 [ 3358 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:11.730947 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:11.820608 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:12.265909 [ 3294 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.430086 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.554635 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.641452 [ 2969 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.662587 [ 3166 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.670063 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:12.725026 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:12.727345 [ 4905 ] {c8239a48-76fe-4a40-a02c-493b564b8cae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43556) (comment: 00662_array_has_nullable.sql) (in query: SELECT has(['a', 'b'], materialize('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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:21:12.746657 [ 4905 ] {c8239a48-76fe-4a40-a02c-493b564b8cae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:21:12.854462 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:13.271751 [ 3425 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.436633 [ 3042 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.586829 [ 3227 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.644499 [ 3388 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.665184 [ 3289 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.672634 [ 3325 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:13.882395 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:14.040956 [ 5300 ] {6d7bc885-81a7-470f-8c9b-b5aadad36dbc} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43634) (comment: 01089_alter_settings_old_format.sql) (in query: ALTER TABLE old_format_mt MODIFY SETTING enable_mixed_granularity_parts = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf5d7 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ec91 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:21:14.050226 [ 5300 ] {6d7bc885-81a7-470f-8c9b-b5aadad36dbc} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf5d7 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ec91 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:21:14.056966 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:14.274087 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:14.442436 [ 3057 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:14.589803 [ 3122 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:14.647299 [ 3119 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:14.667771 [ 3013 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:14.681465 [ 3447 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.071374 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.181618 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.305011 [ 3254 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.428514 [ 5300 ] {0d277a90-37e3-40b8-a2e9-7d49d1f0adc6} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: -- -- error cases -- -- INTERSECT WITH RECURSIVE x AS (SELECT 1 AS n INTERSECT SELECT n+1 FROM x) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.430926 [ 5300 ] {0d277a90-37e3-40b8-a2e9-7d49d1f0adc6} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.444691 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.475316 [ 5300 ] {2b7480ca-7909-4735-94e1-dc20d414707c} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: WITH RECURSIVE x AS (SELECT 1 AS n INTERSECT ALL SELECT n+1 FROM x) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.477382 [ 5300 ] {2b7480ca-7909-4735-94e1-dc20d414707c} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n INTERSECT ALL SELECT n + 1 FROM x) with INTERSECT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.512003 [ 5300 ] {188f8ea4-a9a5-42b2-9af6-2e1e799b568e} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: -- EXCEPT WITH RECURSIVE x AS (SELECT 1 AS n EXCEPT SELECT n+1 FROM x) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.515557 [ 5300 ] {188f8ea4-a9a5-42b2-9af6-2e1e799b568e} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.556187 [ 5300 ] {3a657f1b-6e36-4fb6-8c32-87bb0d38c0a6} executeQuery: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: WITH RECURSIVE x AS (SELECT 1 AS n EXCEPT ALL SELECT n+1 FROM x) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.568669 [ 5300 ] {3a657f1b-6e36-4fb6-8c32-87bb0d38c0a6} TCPHandler: Code: 1. DB::Exception: Recursive CTE subquery x AS (SELECT 1 AS n EXCEPT ALL SELECT n + 1 FROM x) with EXCEPT_ALL union mode is unsupported, only UNION ALL union mode is supported. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000000c938aeb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035e5c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.592697 [ 3337 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.649870 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.669781 [ 3124 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.683264 [ 3434 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:15.702660 [ 5300 ] {5d560ce7-85c4-4382-acfa-38e132e7d198} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope x AS (SELECT n FROM x). (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: -- no non-recursive term WITH RECURSIVE x AS (SELECT n FROM x) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.710930 [ 5300 ] {5d560ce7-85c4-4382-acfa-38e132e7d198} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope x AS (SELECT n FROM x). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 24. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.977780 [ 5300 ] {c44e33f5-16b0-4a69-9370-fefd7b810fa3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope SELECT n FROM x. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: -- recursive term in the left hand side (strictly speaking, should allow this) WITH RECURSIVE x AS (SELECT n FROM x UNION ALL SELECT 1 AS n) SELECT * FROM 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5660: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035309 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:21:15.980647 [ 5300 ] {c44e33f5-16b0-4a69-9370-fefd7b810fa3} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'x' in scope SELECT n FROM x. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5660: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011035309 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3787: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392d0 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.093511 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.307342 [ 3021 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.318361 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.446952 [ 3444 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.595317 [ 3400 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.633934 [ 5300 ] {7b4a0c85-59fd-4315-8d3d-13e877a8708f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43672) (comment: 03040_recursive_cte_postgres_6.sql) (in query: -- LEFT JOIN WITH RECURSIVE x AS (SELECT a AS n FROM y WHERE a = 1 UNION ALL SELECT x.n+1 FROM y LEFT JOIN x ON x.n = y.a WHERE n < 10) SELECT * FROM x FORMAT NULL SETTINGS max_recursive_cte_evaluation_depth = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.652301 [ 3451 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.660749 [ 5300 ] {7b4a0c85-59fd-4315-8d3d-13e877a8708f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.671884 [ 3240 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.687848 [ 3267 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:16.868080 [ 5300 ] {0f1192cb-6aaa-42b8-9413-5860111f5fc0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59182) (comment: 03040_recursive_cte_postgres_6.sql) (in query: DROP DATABASE IF EXISTS test_c8kgrs0h ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:16.880923 [ 5300 ] {0f1192cb-6aaa-42b8-9413-5860111f5fc0} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.071177 [ 4905 ] {fdcf4d56-7f85-43b4-82fe-377632bca7c6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59198) (comment: 03040_recursive_cte_postgres_6.sql) (in query: DROP DATABASE IF EXISTS test_c8kgrs0h ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:17.077828 [ 4905 ] {fdcf4d56-7f85-43b4-82fe-377632bca7c6} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.134291 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:17.244057 [ 76100 ] {a8542675-2c0b-4067-b548-54250912c8b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59202) (comment: 03040_recursive_cte_postgres_6.sql) (in query: DROP DATABASE IF EXISTS test_c8kgrs0h ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:17.247482 [ 76100 ] {a8542675-2c0b-4067-b548-54250912c8b1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.279330 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:17.308025 [ 4905 ] {532b2ba4-d13c-4e74-b612-d16cc88f733e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59212) (comment: 03040_recursive_cte_postgres_6.sql) (in query: DROP DATABASE IF EXISTS test_c8kgrs0h ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:17.308887 [ 2968 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.309941 [ 4905 ] {532b2ba4-d13c-4e74-b612-d16cc88f733e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.449369 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.597621 [ 3363 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.654847 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.676767 [ 2974 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:17.693731 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.294513 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:18.311084 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.403469 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:18.451449 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.657948 [ 3093 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.679566 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.689742 [ 3174 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:18.696883 [ 3368 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.313693 [ 3015 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.457927 [ 3402 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.584828 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:19.609909 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:19.660630 [ 3422 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.684676 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.698760 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:19.703009 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.327743 [ 3431 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.460930 [ 3315 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.665854 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.686657 [ 3080 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.698439 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:20.703551 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.705272 [ 3121 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:20.745406 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:21.333194 [ 3238 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.463376 [ 3313 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.668530 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.688957 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.707604 [ 3429 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.708614 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:21.852521 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:21.877468 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:22.338161 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.465948 [ 3357 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.673537 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.691481 [ 3234 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.710300 [ 3187 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.711181 [ 3385 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:22.927311 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:22.958703 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:23.340526 [ 2986 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:23.469813 [ 3101 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:23.676247 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:23.693849 [ 3306 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:23.713322 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:23.713874 [ 3136 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.022109 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:24.081684 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:24.343059 [ 3275 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.473398 [ 3404 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.678804 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.696318 [ 3066 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.716185 [ 3065 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:24.716697 [ 3455 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.191615 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:25.259473 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:25.346591 [ 3030 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.493585 [ 3022 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.681874 [ 3341 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.701715 [ 3124 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.719360 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:25.720259 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.349960 [ 3165 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.417406 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:26.496274 [ 3420 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.530453 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:26.685107 [ 3475 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.704411 [ 3434 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.722449 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:26.722733 [ 3009 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.383606 [ 3355 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.499234 [ 3251 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.523299 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:27.617617 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:27.686976 [ 3366 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.706625 [ 3056 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.724517 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:27.725550 [ 3128 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.386346 [ 3115 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.501710 [ 3249 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.689388 [ 3447 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.709421 [ 3468 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.728122 [ 3301 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.729927 [ 3224 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:28.740275 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:28.890751 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:29.388328 [ 3032 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.507735 [ 3219 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.691730 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.714601 [ 3240 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.733791 [ 3091 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.734388 [ 3255 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:29.840053 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:29.932868 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:30.390934 [ 3228 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.510796 [ 3147 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.694660 [ 3189 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.729442 [ 3430 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.736152 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.747031 [ 3132 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:30.957282 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:31.018632 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:31.394333 [ 3334 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:31.513647 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:31.697806 [ 3376 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:31.736332 [ 2970 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:31.739050 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:31.750274 [ 3203 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.181639 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:32.220976 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:32.396842 [ 3118 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.516967 [ 3364 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.700729 [ 3067 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.739422 [ 3372 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.741710 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:32.852260 [ 3153 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.359540 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:33.388648 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:33.399773 [ 3380 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.519061 [ 3016 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.666743 [ 5300 ] {c88ff477-2086-429f-bd5a-26f4d84844e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49226) (comment: 00964_bloom_index_string_functions.sh) (in query: SELECT * FROM bloom_filter_idx WHERE startsWith(s, 'c') AND endsWith(s, 'science')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:33.689680 [ 5300 ] {c88ff477-2086-429f-bd5a-26f4d84844e3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:33.703456 [ 3127 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.743754 [ 3241 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.745768 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:33.859168 [ 3436 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.381969 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:34.403139 [ 3151 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.427303 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:34.521659 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.706513 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.748493 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.751006 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:34.868599 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.402862 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:35.405437 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.496052 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:35.524466 [ 3049 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.709556 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.751426 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.756354 [ 3368 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:35.873298 [ 3064 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.411030 [ 3377 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.411984 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:36.463581 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:36.589141 [ 3122 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.712226 [ 3212 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.754300 [ 3365 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.758946 [ 3033 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:36.876017 [ 3231 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.416324 [ 3060 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.493818 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:37.544663 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:37.591649 [ 3175 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.715606 [ 2988 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.757002 [ 3398 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.761395 [ 3051 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:37.878891 [ 3080 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.418814 [ 3371 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.597066 [ 3400 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.650269 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:38.683747 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:38.717403 [ 3424 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.759251 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.763527 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:38.881201 [ 3028 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.421521 [ 3073 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.599659 [ 3363 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.719071 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.771019 [ 3011 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.773061 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.785467 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.816221 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.883472 [ 3085 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.952217 [ 5300 ] {d425aa18-0bc1-42cd-a713-b19017462e4e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58662) (comment: 00964_bloom_index_string_functions.sh) (in query: SELECT * FROM bloom_filter_idx WHERE multiSearchAny(s, ['string', 'computer'])), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.959504 [ 76521 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50224, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.961251 [ 5300 ] {d425aa18-0bc1-42cd-a713-b19017462e4e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131cee52 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.968693 [ 8202 ] {8b059679-cce7-4fb1-ba0c-dd7b2ae09653} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:51130). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51130) (comment: 00964_bloom_index_string_functions.sh) (in query: SELECT `__table1`.`k` AS `k`, `__table1`.`s` AS `s` FROM `test_2ln47sba`.`bloom_filter_idx` AS `__table1` WHERE multiSearchAny(`__table1`.`s`, _CAST(['string', 'computer'], 'Array(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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.979128 [ 8202 ] {8b059679-cce7-4fb1-ba0c-dd7b2ae09653} 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]:51130). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:39.983395 [ 8202 ] {8b059679-cce7-4fb1-ba0c-dd7b2ae09653} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:51130). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:21:39.989110 [ 8202 ] {8b059679-cce7-4fb1-ba0c-dd7b2ae09653} TCPHandler: Client has gone away. 2025.09.25 21:21:40.426661 [ 3244 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.603061 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.721208 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.775556 [ 3490 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.780043 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.860761 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:40.885737 [ 3143 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:40.926829 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:41.437557 [ 3221 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.605638 [ 3155 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.723413 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.778067 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.782394 [ 3055 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.888088 [ 3374 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:41.891805 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:41.965355 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:42.440255 [ 3402 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.607394 [ 3354 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.733327 [ 3234 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.780376 [ 2996 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.784941 [ 3303 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.888401 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:42.893944 [ 3216 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:42.902610 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:43.445520 [ 3448 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.610731 [ 2995 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.765868 [ 3114 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.782371 [ 3352 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.786875 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.897440 [ 5300 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:43.898036 [ 3275 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:43.909077 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:44.448075 [ 3183 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.612320 [ 3458 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.768609 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.784466 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.792175 [ 3096 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.880837 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:44.900702 [ 3014 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:44.967349 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:45.449773 [ 3018 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:45.617019 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:45.780166 [ 3162 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:45.782043 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:45.786381 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:45.794246 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:45.879840 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:45.902404 [ 3112 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.451998 [ 3330 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.621979 [ 3195 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.785737 [ 3246 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.788760 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.800887 [ 3066 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:46.846090 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:46.904927 [ 3092 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.052765 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:47.455340 [ 3177 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.626878 [ 3290 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.696765 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:47.791040 [ 3241 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.791619 [ 3074 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.803128 [ 3036 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:47.911701 [ 3397 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.148348 [ 4905 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.159995 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:48.456873 [ 3444 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.632695 [ 3373 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.732961 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:48.793686 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.794280 [ 3098 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.811545 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:48.917759 [ 3479 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.236436 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:49.460096 [ 3068 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.640600 [ 3081 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.797041 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.799382 [ 3193 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.813741 [ 3033 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:49.830866 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:49.920787 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.282684 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:50.464931 [ 3173 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.643986 [ 3215 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.808687 [ 3368 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.813289 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.816335 [ 3403 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.923993 [ 3465 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:50.996884 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:51.435586 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:51.472090 [ 3313 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:51.649317 [ 3119 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:51.815856 [ 3359 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:51.816372 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:51.818650 [ 3359 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:51.926545 [ 3367 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.144702 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:52.474620 [ 3183 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.482056 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:52.652514 [ 3271 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.818789 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.821042 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.821409 [ 3353 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:52.928708 [ 3047 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.320379 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:53.477396 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.581728 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:53.654315 [ 3283 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.828772 [ 3153 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.829530 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.830779 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:53.932758 [ 3222 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.188680 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:54.479433 [ 3292 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.604464 [ 4905 ] {3ae59ed1-840e-4ee9-b461-eae80359e0b9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48690) (comment: 02477_exists_fuzz_43478.sql) (in query: DROP DATABASE IF EXISTS test_b8rcbibl ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:54.606974 [ 4905 ] {3ae59ed1-840e-4ee9-b461-eae80359e0b9} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.656792 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.682497 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:54.693217 [ 76521 ] {d3562050-32a6-4b8a-97d2-092fa9921d56} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48700) (comment: 02477_exists_fuzz_43478.sql) (in query: DROP DATABASE IF EXISTS test_b8rcbibl ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:54.696501 [ 76521 ] {d3562050-32a6-4b8a-97d2-092fa9921d56} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.834326 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.834843 [ 3390 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.835372 [ 3243 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.913578 [ 4905 ] {4f43bde3-5017-496d-b485-b2b1f93412bc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:48702) (comment: 02477_exists_fuzz_43478.sql) (in query: DROP DATABASE IF EXISTS test_b8rcbibl ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:21:54.917380 [ 4905 ] {4f43bde3-5017-496d-b485-b2b1f93412bc} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:54.935094 [ 2987 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.215478 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:55.481203 [ 3139 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.589862 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:55.658771 [ 3413 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.836723 [ 3064 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.837259 [ 3225 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.842935 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:55.938227 [ 3379 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.191227 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:56.483199 [ 3029 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.653040 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:56.660978 [ 3458 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.839409 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.845588 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.847841 [ 3080 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:56.943915 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.127023 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:57.413262 [ 3592 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_137_158_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.500586 [ 3249 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.663007 [ 3440 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.732158 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:57.843804 [ 3210 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.848202 [ 2985 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.850289 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:57.946447 [ 3130 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.100007 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:58.502674 [ 2992 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.667507 [ 3097 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.775342 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:58.845394 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.850121 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.852356 [ 3476 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:58.954641 [ 3262 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.090466 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:59.505594 [ 3242 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.587765 [ 4905 ] {cd7069e4-3e62-4611-871b-2598b8d62fd0} executeQuery: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34498) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 SETTINGS ignore_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000013190513 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001318eafd 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::SourceStepWithFilter::applyFilters() @ 0x000000001320027a 7. /build/src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000013200145 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fea53 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 10. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:21:59.593267 [ 4905 ] {cd7069e4-3e62-4611-871b-2598b8d62fd0} TCPHandler: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1520: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000013190513 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1617: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001318eafd 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::SourceStepWithFilter::applyFilters() @ 0x000000001320027a 7. /build/src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:51: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000013200145 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fea53 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 10. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:21:59.669703 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.802974 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:21:59.859533 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.864397 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.875060 [ 3143 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:21:59.956576 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.024803 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.337784 [ 4905 ] {714c1da3-6348-4e59-95bb-4607f21d873d} executeQuery: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34498) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 WHERE x = 1 AND y = 1 SETTINGS ignore_data_skipping_indices='xy_idx',force_data_skipping_indices='xy_idx' ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 10. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.371700 [ 4905 ] {714c1da3-6348-4e59-95bb-4607f21d873d} TCPHandler: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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) @ 0x000000001285520a 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) @ 0x000000001318dc24 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 10. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 22. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.507954 [ 3364 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.674243 [ 3195 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.717806 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.793767 [ 4905 ] {d609b50f-8788-4a73-8823-687631d4b591} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34498) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.796254 [ 4905 ] {d609b50f-8788-4a73-8823-687631d4b591} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.865558 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.873776 [ 2997 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.877999 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.906954 [ 4905 ] {f80c2c86-a828-4228-826b-fa7b5bf0a926} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49574) (comment: 02771_ignore_data_skipping_indices.sql) (in query: DROP DATABASE IF EXISTS test_rfcrwzm7 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.909468 [ 4905 ] {f80c2c86-a828-4228-826b-fa7b5bf0a926} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.933825 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.958556 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:00.977516 [ 76541 ] {3af3b252-869b-4970-ae58-a0772b43c904} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49580) (comment: 02771_ignore_data_skipping_indices.sql) (in query: DROP DATABASE IF EXISTS test_rfcrwzm7 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:00.979843 [ 76541 ] {3af3b252-869b-4970-ae58-a0772b43c904} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.520996 [ 3181 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.679837 [ 3017 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.856636 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:01.867834 [ 3483 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.876128 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.880089 [ 3234 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:01.960974 [ 3187 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.000943 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:02.527472 [ 3050 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.682735 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.869556 [ 3385 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.877699 [ 3297 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.882842 [ 3273 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:02.927613 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:02.963138 [ 3184 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.063398 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:03.194349 [ 4905 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:03.529422 [ 3268 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.589210 [ 4905 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:03.684656 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.840309 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:03.872037 [ 3197 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.879587 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.885823 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.964680 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:03.980076 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:04.047885 [ 76521 ] {9519abd0-2e1d-43f2-9c97-72608eed5482} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34640) (comment: 01825_type_json_schema_inference.sh) (in query: SELECT * FROM t_json_inference 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:22:04.056087 [ 76521 ] {9519abd0-2e1d-43f2-9c97-72608eed5482} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:22:04.531998 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:04.690469 [ 3451 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:04.857810 [ 4905 ] {a982fef0-b065-4431-83ef-a0e4aca1d3f1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:34656) (comment: 01825_type_json_schema_inference.sh) (in query: SELECT toTypeName(obj) FROM t_json_inference 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:22:04.874592 [ 3427 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:04.885790 [ 4905 ] {a982fef0-b065-4431-83ef-a0e4aca1d3f1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:22:04.888837 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:04.893369 [ 3086 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:04.969962 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.131981 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:05.195658 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:05.537695 [ 3232 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.698676 [ 3240 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.876692 [ 3435 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.891592 [ 3169 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.896194 [ 3482 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:05.973057 [ 3014 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.255320 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:06.280699 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:06.540353 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.704022 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.879173 [ 3312 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.893926 [ 3109 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.898814 [ 3186 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:06.975156 [ 3046 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.178468 [ 4905 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:07.328879 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:07.330595 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:07.542683 [ 3299 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.708536 [ 3107 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.881437 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.896320 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.904067 [ 3123 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:07.977243 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.207792 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:08.221564 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:08.368390 [ 4905 ] {2ea55475-a862-44a8-96a0-7ad36d408622} 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.10508.altinitytest (altinity build)) (from [::1]:50192) (comment: 01825_type_json_schema_inference.sh) (in query: DROP DATABASE IF EXISTS test_l75rxoir ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:22:08.371861 [ 4905 ] {2ea55475-a862-44a8-96a0-7ad36d408622} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.546289 [ 2991 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.710651 [ 3399 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.883866 [ 3330 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.902725 [ 3202 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.906283 [ 3339 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:08.979660 [ 3378 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.180361 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:09.284327 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:09.548063 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.712594 [ 3468 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.885997 [ 3247 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.904549 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.908275 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:09.981977 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.105608 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:10.226348 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:10.551924 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.714321 [ 3035 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.889900 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.906300 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.909717 [ 3476 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.983768 [ 3483 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:10.997350 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:11.161574 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:11.553917 [ 2991 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:11.716546 [ 3240 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:11.891924 [ 3070 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:11.915996 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:11.926126 [ 3011 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:11.938758 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:11.985734 [ 3217 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.091311 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:12.122949 [ 7604 ] {567e58e6-94f0-494a-9848-65d4be0f3de7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52672) (comment: 01392_column_resolve.sql) (in query: DROP DATABASE IF EXISTS test_ztnmpvyk ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:12.124410 [ 7604 ] {567e58e6-94f0-494a-9848-65d4be0f3de7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.555739 [ 3395 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.721598 [ 3142 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.894251 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.919825 [ 3490 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.938765 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:12.974915 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:12.990283 [ 3303 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.244047 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:13.558123 [ 3279 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.730710 [ 3009 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.896387 [ 3456 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.922605 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.941364 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:13.976157 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:14.001321 [ 3385 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.034965 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8f25176d-6bf0-484f-b27f-d635da64b3f4::202509_1_140_47}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.242300 [ 76521 ] {8bfea3ff-2357-4412-96b9-6c4e959bab7a} executeQuery: Code: 57. DB::Exception: Table test_hpv18bnq.subcolumns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32894) (comment: 01475_read_subcolumns_storages.sh) (in query: CREATE TABLE subcolumns(n Nullable(UInt32), a1 Array(UInt32), a2 Array(Array(Array(UInt32))), a3 Array(Nullable(UInt32)), t Tuple(s String, v UInt32), m Map(String, UInt32)) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:14.262924 [ 76521 ] {8bfea3ff-2357-4412-96b9-6c4e959bab7a} TCPHandler: Code: 57. DB::Exception: Table test_hpv18bnq.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:14.277002 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:14.449466 [ 76521 ] {a41c7a82-3325-418e-b236-d2ae0b4ea638} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50242) (comment: 01475_read_subcolumns_storages.sh) (in query: DROP DATABASE IF EXISTS test_hpv18bnq ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:14.535688 [ 76521 ] {a41c7a82-3325-418e-b236-d2ae0b4ea638} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.560802 [ 3126 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.734106 [ 3045 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.906799 [ 3135 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.925312 [ 3450 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:14.944049 [ 3130 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.006464 [ 3197 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.048959 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:15.297938 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:15.563696 [ 2982 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.736797 [ 3224 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.909395 [ 3143 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.929124 [ 2987 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:15.947192 [ 2997 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:16.009502 [ 3414 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:16.331698 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:16.400758 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:16.566555 [ 3281 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:16.739981 [ 3091 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:16.914731 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:16.949869 [ 3374 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.016092 [ 3145 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.028981 [ 3379 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.076411 [ 76521 ] {5f04c6ef-abca-43f1-8eb4-5502fcab6579} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:32910) (comment: 01821_join_table_mutation.sql) (in query: ALTER TABLE join_table_mutation UPDATE name = 'some' WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000122920ad 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153eebc 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:17.093694 [ 76521 ] {5f04c6ef-abca-43f1-8eb4-5502fcab6579} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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/StorageJoin.cpp:165: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000122920ad 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153eebc 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:17.387422 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:17.460210 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:17.571621 [ 3084 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.742715 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.921578 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:17.962095 [ 3218 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.018846 [ 2998 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.032018 [ 3381 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.444782 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:18.576815 [ 3337 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.604434 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:18.744871 [ 2970 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.924321 [ 3262 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:18.967713 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.021743 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.037141 [ 3178 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.573994 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:19.579322 [ 3146 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.797454 [ 3203 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.913865 [ 76541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:19.933126 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:19.970245 [ 3449 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.027084 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.039858 [ 3362 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.581767 [ 2983 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.649020 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:20.800268 [ 3048 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.935735 [ 3445 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:20.972807 [ 3187 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.026442 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:21.029621 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.042254 [ 3386 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.584924 [ 3041 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.652254 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:21.802206 [ 3415 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.982797 [ 3274 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:21.983332 [ 3125 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.032146 [ 3350 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.047514 [ 3053 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.079682 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:22.511559 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:22.586740 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.808481 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.984652 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.985351 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:22.986469 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:23.033974 [ 3457 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:23.049506 [ 3343 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:23.371667 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:23.593743 [ 3408 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:23.811928 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:23.882148 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:23.986852 [ 3162 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:23.988284 [ 3286 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.035535 [ 3186 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.051210 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.172360 [ 76521 ] {0639d073-e34c-40f6-a869-235b0b43a6f1} executeQuery: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50710) (comment: 02864_statistics_bugs.sql) (in query: SELECT count(*) FROM bug_67742 WHERE a < '10.5';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x00000000084e1c4b 4. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118da616 5. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 6. /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 @ 0x0000000009be4e92 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009bca9e6 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) @ 0x0000000010fcb9e1 14. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 15. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 16. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&) @ 0x0000000011625c38 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>>&) @ 0x0000000011654949 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 20. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 21. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 23. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 24. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 25. /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&) @ 0x000000001166213c 26. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 27. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 28. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 29. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:22:24.173705 [ 76521 ] {0639d073-e34c-40f6-a869-235b0b43a6f1} TCPHandler: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x00000000084e1c4b 4. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118da616 5. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d70f5 6. /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 @ 0x0000000009be4e92 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009bca9e6 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) @ 0x0000000010fcb9e1 14. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 15. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0690 16. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151563 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&) @ 0x0000000011625c38 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>>&) @ 0x0000000011654949 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e5f5 20. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 21. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x00000000116480f7 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000116481ef 23. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1eae3 24. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116691a2 25. /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&) @ 0x000000001166213c 26. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d610 27. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 28. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 29. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 2025.09.25 21:22:24.275565 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:24.672842 [ 3271 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.712513 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:24.813953 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.989397 [ 3206 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:24.992772 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.037701 [ 3472 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.053366 [ 3092 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.302763 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:25.674801 [ 3366 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.819617 [ 3025 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.836991 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:25.861453 [ 76521 ] {01a0ed74-77fc-4d55-a5e4-84104510a8a5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50710) (comment: 02864_statistics_bugs.sql) (in query: INSERT INTO bug_67742 SELECT number FROM system.numbers 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:22:25.866400 [ 76521 ] {01a0ed74-77fc-4d55-a5e4-84104510a8a5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:22:25.991521 [ 2984 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:25.994821 [ 3211 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.040450 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.061360 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.095664 [ 76521 ] {4b89cfa6-e6ba-4fb6-a0bd-d274e73dd5f7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43064) (comment: 02864_statistics_bugs.sql) (in query: DROP DATABASE IF EXISTS test_s6gmf8y3 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:26.106294 [ 76521 ] {4b89cfa6-e6ba-4fb6-a0bd-d274e73dd5f7} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.299680 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:26.677101 [ 3452 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.822149 [ 2994 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:26.952774 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:26.996412 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.042500 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.063632 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.064129 [ 3323 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.278794 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:27.679050 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.824546 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:27.894149 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:27.998870 [ 3207 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.046485 [ 3416 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.066328 [ 3380 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.069103 [ 3334 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.215644 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:28.680998 [ 3368 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.826653 [ 3183 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:28.864832 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:29.001295 [ 3202 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.048721 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.068854 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.071841 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.169267 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:29.683292 [ 3341 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.829722 [ 2994 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:29.953278 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:30.004396 [ 3197 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:30.051623 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:30.071146 [ 3141 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:30.173418 [ 3346 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:30.292383 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:30.685661 [ 3017 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:30.832045 [ 3025 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.006900 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:31.007683 [ 3125 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.053854 [ 3362 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.073735 [ 3010 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.176091 [ 3116 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.332750 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:31.687706 [ 3475 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:31.837397 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.015690 [ 3433 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.056521 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.076607 [ 3159 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.178853 [ 2979 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.355236 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:32.512945 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:32.540426 [ 76521 ] {c018857b-039e-43e2-80c0-cd16e8bc9817} executeQuery: Code: 57. DB::Exception: Table test_o988xi87.kstest already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51636) (comment: 02706_kolmogorov_smirnov_test.sql) (in query: CREATE TABLE kstest (left Float64, right Float64) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:32.546375 [ 76521 ] {c018857b-039e-43e2-80c0-cd16e8bc9817} TCPHandler: Code: 57. DB::Exception: Table test_o988xi87.kstest 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:32.691503 [ 3366 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:32.841551 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.023553 [ 3145 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.062185 [ 3160 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.079244 [ 3370 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.181838 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.372693 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:33.542725 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:33.697358 [ 3447 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:33.844201 [ 3353 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.026503 [ 2998 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.065293 [ 3438 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.081618 [ 3205 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.184675 [ 3351 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.589628 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:34.669441 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:34.705409 [ 3434 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.850637 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:34.909606 [ 4770 ] {73982bfd-1276-46d7-8a3a-6b7895f8fd7e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38020) (comment: 01710_aggregate_projection_with_normalized_states.sql) (in query: SELECT ifNotFinite(quantilesTimingMerge(0.95)(`__table1`.`q`)[1], 0) AS `d1`, ifNotFinite(quantilesTimingMerge(0.99)(`__table1`.`q`)[1], 0) AS `d2`, ifNotFinite(quantilesTimingMerge(0.5)(`__table1`.`q`)[1], 0) AS `d3`, sum(`__table1`.`s`) AS `sum(s)` FROM `test_nb2p9838`.`r` AS `__table1` WHERE `__table1`.`a` = '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:22:34.914696 [ 4770 ] {73982bfd-1276-46d7-8a3a-6b7895f8fd7e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.029059 [ 3381 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.071132 [ 3481 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.088856 [ 3000 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.095933 [ 76521 ] {cc173a76-55bc-40e4-abda-24679140bcb0} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:51704) (comment: 01710_aggregate_projection_with_normalized_states.sql) (in query: SELECT ifNotFinite(quantilesTimingMerge(0.95)(q)[1],0) as d1, ifNotFinite(quantilesTimingMerge(0.99)(q)[1],0) as d2, ifNotFinite(quantilesTimingMerge(0.50)(q)[1],0) as d3, sum(s) FROM cluster('test_cluster_two_shards', currentDatabase(), r) WHERE a = 'x' 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:22:35.107290 [ 76521 ] {cc173a76-55bc-40e4-abda-24679140bcb0} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:22:35.160463 [ 7604 ] {2b337f61-028d-4a47-9b9b-da1056faffbb} 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]:42178). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42178) (comment: 01710_aggregate_projection_with_normalized_states.sql) (in query: SELECT ifNotFinite(quantilesTimingMerge(0.95)(`__table1`.`q`)[1], 0) AS `d1`, ifNotFinite(quantilesTimingMerge(0.99)(`__table1`.`q`)[1], 0) AS `d2`, ifNotFinite(quantilesTimingMerge(0.5)(`__table1`.`q`)[1], 0) AS `d3`, sum(`__table1`.`s`) AS `sum(s)` FROM `test_nb2p9838`.`r` AS `__table1` WHERE `__table1`.`a` = '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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.177893 [ 7604 ] {2b337f61-028d-4a47-9b9b-da1056faffbb} 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]:42178). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012ccb8af 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0042 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb54b5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.179622 [ 7604 ] {2b337f61-028d-4a47-9b9b-da1056faffbb} 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]:42178). (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) @ 0x00000000164833b2 1. /build/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&) @ 0x0000000012cc3741 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf331 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.183972 [ 7604 ] {2b337f61-028d-4a47-9b9b-da1056faffbb} TCPHandler: Client has gone away. 2025.09.25 21:22:35.187376 [ 3463 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.398761 [ 76521 ] {25916bd4-ef50-4839-844b-685d5570ae04} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36902) (comment: 01710_aggregate_projection_with_normalized_states.sql) (in query: DROP DATABASE IF EXISTS test_nb2p9838 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.412847 [ 76521 ] {25916bd4-ef50-4839-844b-685d5570ae04} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.685282 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.707877 [ 3451 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:35.831372 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:35.853148 [ 3437 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.032039 [ 3322 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.073805 [ 3171 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.094185 [ 3039 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.192834 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.710224 [ 3468 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.859417 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:36.896237 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:37.034624 [ 3328 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:37.041614 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:37.076405 [ 3044 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:37.184223 [ 3307 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:37.198159 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:37.712781 [ 3035 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:37.861704 [ 3225 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.041489 [ 3137 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.079253 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.108434 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:38.191480 [ 3443 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.200881 [ 3266 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.257551 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:38.716274 [ 3487 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:38.864519 [ 3051 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.043786 [ 3270 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.081696 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.193897 [ 3428 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.203779 [ 3204 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.233003 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:39.342259 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:39.718749 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:39.869744 [ 3226 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.046278 [ 3384 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.084298 [ 3464 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.196328 [ 3326 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.206016 [ 3079 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.349825 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:40.508251 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:40.721842 [ 3224 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:40.871957 [ 3080 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.052944 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.086633 [ 3140 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.198613 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.211630 [ 3186 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.517802 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:41.722828 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:41.724621 [ 3301 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:41.874528 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.056074 [ 3298 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.089831 [ 3435 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.204110 [ 3066 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.214138 [ 3065 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.726845 [ 3256 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:42.743062 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:42.856738 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:42.879505 [ 3412 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.059091 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.092138 [ 3482 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.206582 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.219441 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.279735 [ 3593 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f9f14ac-a7f9-4a39-ab2c-54a9eade7757::202509_1_134_30}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.729885 [ 3167 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.734450 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:43.886046 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:43.979327 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:44.062280 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:44.094738 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:44.210781 [ 3092 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:44.221273 [ 3356 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:44.353531 [ 76521 ] {846deef4-5fa6-4107-bf26-f98c063bc568} executeQuery: Code: 57. DB::Exception: Table test_qp81wc5c.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33368) (comment: 02661_read_from_archive_targz.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_qp81wc5c_targz_archive{1..2}.tar.gz :: 02661_read_from_archive_test_qp81wc5c_targz_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:44.372006 [ 76521 ] {846deef4-5fa6-4107-bf26-f98c063bc568} TCPHandler: Code: 57. DB::Exception: Table test_qp81wc5c.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:44.616763 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:44.732515 [ 3132 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:44.888579 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.009007 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:45.064778 [ 3078 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.097542 [ 3387 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.213513 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.228085 [ 3254 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.735050 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:45.746574 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:45.890451 [ 3465 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.067480 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.103217 [ 3229 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.107275 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:46.215662 [ 3003 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.241568 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.740059 [ 3241 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:46.824559 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:46.901348 [ 3450 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.069566 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.108156 [ 3315 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.116718 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:47.217377 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.243338 [ 3272 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.738589 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:47.746099 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:47.908362 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.007819 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:48.071902 [ 3357 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.109972 [ 3235 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.220968 [ 3441 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.244968 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.638500 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:48.747992 [ 3093 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:48.887337 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:48.909989 [ 3304 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.073845 [ 3219 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.117736 [ 3049 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.222831 [ 3336 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.246512 [ 3232 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.603202 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:49.749801 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.806728 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:49.913985 [ 3216 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:49.992214 [ 3598 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_137_164_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.077140 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.126446 [ 3265 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.225473 [ 3360 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.248932 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.756347 [ 3212 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:50.805816 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:50.857883 [ 7604 ] {47ee5917-05b1-4d0b-93af-f45a180df8cb} executeQuery: Code: 57. DB::Exception: Table test_qp81wc5c.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59962) (comment: 02661_read_from_archive_targz.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_qp81wc5c_targz_archive3.tar.gz :: 02661_read_from_archive_test_qp81wc5c_targz_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:50.866790 [ 7604 ] {47ee5917-05b1-4d0b-93af-f45a180df8cb} TCPHandler: Code: 57. DB::Exception: Table test_qp81wc5c.`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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:22:50.917737 [ 3352 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.036249 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:51.078566 [ 3101 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.128070 [ 3464 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.228354 [ 3266 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.255261 [ 3406 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.774227 [ 3430 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.919964 [ 3429 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:51.931539 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:52.052069 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:52.081031 [ 3010 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:52.133557 [ 3391 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:52.231557 [ 3079 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:52.257959 [ 3467 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:52.776578 [ 3067 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:52.922597 [ 3465 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:53.136408 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:53.152715 [ 3159 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:53.237653 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:53.264110 [ 3405 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:53.279270 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:53.337739 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:53.781413 [ 2964 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.008551 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.139164 [ 3169 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.166032 [ 3134 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.252532 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.266614 [ 3453 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:54.560739 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:54.599798 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:54.787941 [ 2990 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.014442 [ 3414 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.142630 [ 3482 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.169129 [ 3312 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.254920 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.268296 [ 3110 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:55.578088 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:55.629970 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:55.790382 [ 3127 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.054552 [ 3362 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.144964 [ 3457 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.177247 [ 3109 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.256693 [ 3182 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.270651 [ 3190 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:56.481384 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:56.668693 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:56.792830 [ 3241 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.056977 [ 3156 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.149477 [ 3343 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.178851 [ 3324 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.261464 [ 3316 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.273059 [ 3477 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:57.563535 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:57.663683 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:57.795368 [ 3193 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.059114 [ 3141 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.151058 [ 3404 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.200565 [ 3317 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.263622 [ 3387 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.278117 [ 3269 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:58.510618 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:58.750586 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:58.799472 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.061708 [ 3346 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.153785 [ 3423 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.208833 [ 3263 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.265889 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.284164 [ 3211 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.678088 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:22:59.815730 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:22:59.830321 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:00.064163 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:00.169104 [ 3108 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:00.211812 [ 2981 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:00.273378 [ 3123 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:00.287178 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:00.670584 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:00.797000 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:00.818475 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.069802 [ 3386 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.171829 [ 3443 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.218255 [ 3428 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.278051 [ 3209 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.289193 [ 3213 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:01.628682 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:01.674353 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:01.820774 [ 2994 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.071676 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.176037 [ 3112 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.220763 [ 3326 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.279743 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.291069 [ 2968 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:02.525541 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:02.581498 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:02.825614 [ 3088 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.076774 [ 3276 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.180836 [ 3246 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.222713 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.282109 [ 3361 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.295996 [ 3015 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:03.523222 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:03.574813 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:03.830382 [ 3353 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.083885 [ 3065 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.183581 [ 3356 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.224642 [ 3431 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.286425 [ 3131 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.300910 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:04.656811 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:04.662912 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:04.755661 [ 7604 ] {1c74dfaf-93e5-4a5e-9fbe-16c45173fb80} Context: Server has databases (for example `test_01155_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.09.25 21:23:04.832479 [ 3153 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.086037 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.185618 [ 2986 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.226797 [ 3394 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.376963 [ 3344 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.377177 [ 3355 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:05.556648 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:05.635265 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:05.834458 [ 3437 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.087917 [ 3118 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.187763 [ 3151 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.228945 [ 3019 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.379028 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.379403 [ 3173 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:06.426815 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:06.530595 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:06.836634 [ 3064 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.032780 [ 76100 ] {bcf9e964-4e56-42b6-b4ae-79ca61065eb3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48450) (comment: 01155_rename_move_materialized_view.sql) (in query: SELECT materialize(1) AS `materialize(1)`, substring(__actionName('dst', '__table1._table'), 1, 10) AS `substr(_table, 1, 10)`, `__table1`.`s` AS `s` FROM `test_01155_ordinary`.`dst` AS `__table1` ORDER BY __actionName('dst', '__table1._table') ASC, `__table1`.`s` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:07.036821 [ 76100 ] {bcf9e964-4e56-42b6-b4ae-79ca61065eb3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:07.089826 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.189712 [ 3399 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.204102 [ 7604 ] {ea5e1cf3-f180-4f6e-9f5c-3ee47f8fc7e6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41404) (comment: 01155_rename_move_materialized_view.sql) (in query: -- FIXME Cannot convert column `1` because it is non constant in source stream but must be constant in result SELECT materialize(1), substr(_table, 1, 10), s FROM merge('test_01155_ordinary', '') ORDER BY _table, 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:23:07.210679 [ 4816 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57534, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.234948 [ 3022 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.299682 [ 4665 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49410, local: [::ffff:127.0.0.8]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.312478 [ 7604 ] {ea5e1cf3-f180-4f6e-9f5c-3ee47f8fc7e6} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:23:07.348460 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:07.380914 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.383691 [ 3018 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:07.560253 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:07.840596 [ 3247 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.097332 [ 3291 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.191333 [ 3420 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.216261 [ 77647 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.238273 [ 3466 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.247346 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:08.271541 [ 4770 ] {9e4bcdc9-b759-436f-88f2-6e15402ef498} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52224) (comment: 00833_sleep_overflow.sql) (in query: SELECT sleep(4295.967296);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&) @ 0x000000000702de8b 4. /build/src/Functions/sleep.h:119: DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61be61 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61b74c 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/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197afd 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 13. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 19. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:23:08.273271 [ 4770 ] {9e4bcdc9-b759-436f-88f2-6e15402ef498} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&) @ 0x000000000702de8b 4. /build/src/Functions/sleep.h:119: DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61be61 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61b74c 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/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197afd 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fad856 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a4b3 13. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50749 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 19. /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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:23:08.382945 [ 3049 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.385466 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:08.461347 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:08.884845 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.098935 [ 3148 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.170535 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:09.194587 [ 3061 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.239815 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.357135 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:09.386219 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.391287 [ 3388 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:09.896232 [ 3439 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.104309 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.197470 [ 3097 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.218445 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:10.245151 [ 3023 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.390842 [ 3258 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.397181 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:10.436233 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:10.898275 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.106105 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.114839 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:11.199395 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.247123 [ 3187 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.316286 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:11.392859 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.399291 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:11.900461 [ 3121 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.001777 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:12.108018 [ 3133 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.199662 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:12.200891 [ 3317 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.249172 [ 3356 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.394794 [ 3118 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.407950 [ 3409 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.719467 [ 4905 ] {0fc26dfe-f6a2-45a8-84f7-ea6fda95023d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50234) (comment: 01392_column_resolve.sql) (in query: DROP DATABASE IF EXISTS test_ztnmpvyk ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:23:12.721095 [ 4905 ] {0fc26dfe-f6a2-45a8-84f7-ea6fda95023d} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.845639 [ 4905 ] {16147396-bf7d-44f3-b7ee-d303fd5fa95a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50510) (comment: 01392_column_resolve.sql) (in query: DROP DATABASE IF EXISTS test_ztnmpvyk ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:23:12.848742 [ 4905 ] {16147396-bf7d-44f3-b7ee-d303fd5fa95a} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:12.881415 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:12.902306 [ 3210 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.106210 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:13.118091 [ 3039 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.202450 [ 3263 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.251040 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.412664 [ 3302 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.414847 [ 3105 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.766292 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:13.784588 [ 3593 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5f9f14ac-a7f9-4a39-ab2c-54a9eade7757::202509_1_139_31}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:13.903975 [ 3412 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.087073 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:14.119711 [ 3350 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.203824 [ 3307 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.252524 [ 3161 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.416320 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.416691 [ 3157 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.674980 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:14.905681 [ 3075 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:14.993277 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:15.121779 [ 3053 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:15.205328 [ 3443 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:15.253990 [ 3405 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:15.422009 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:15.422533 [ 3024 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:15.593340 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:15.921276 [ 2978 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.124185 [ 3464 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.207643 [ 3326 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.260390 [ 3082 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.298750 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:16.424836 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.425298 [ 3221 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:16.892236 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:16.924170 [ 3143 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.127363 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.210830 [ 3026 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.263404 [ 3425 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.417643 [ 76100 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:17.427273 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.428192 [ 3421 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.926535 [ 3055 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:17.945541 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:18.140097 [ 3435 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:18.212984 [ 3186 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:18.268141 [ 3477 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:18.490762 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:18.491079 [ 3339 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:18.547576 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:18.837070 [ 4770 ] {d47e9986-b426-4537-adee-45159093db54} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52392) (comment: 00502_sum_map.sql) (in query: select sumMap(val, cnt) from ( SELECT [ CAST('01234567-89ab-cdef-0123-456789abcdef', 'UUID') ] as val, [1] as cnt );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:18.840274 [ 4770 ] {d47e9986-b426-4537-adee-45159093db54} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:18.933331 [ 3342 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.016269 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:19.146418 [ 3014 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.215785 [ 3246 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.306553 [ 3209 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.493457 [ 3249 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.494140 [ 3219 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:19.555954 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:19.860415 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:19.934992 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.151625 [ 3134 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.218228 [ 3066 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.308713 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.496566 [ 3147 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.496913 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:20.581946 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:20.827414 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:20.938238 [ 3319 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.159261 [ 3423 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.223996 [ 3455 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.314120 [ 3007 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.500348 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.522793 [ 3050 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:21.666526 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:21.903587 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:21.940646 [ 3188 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.161744 [ 3472 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.229871 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.403338 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.502709 [ 3052 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.525707 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.686747 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:22.942854 [ 3218 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:22.978264 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:23.164814 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:23.232334 [ 3396 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:23.406674 [ 3022 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:23.504323 [ 2991 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:23.527383 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:23.668333 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:23.948084 [ 3163 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.054374 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:24.170284 [ 3278 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.235499 [ 3323 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.411889 [ 3441 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.506292 [ 3408 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.534187 [ 3285 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:24.755382 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:24.950561 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.068387 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:25.175568 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.238255 [ 3344 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.416799 [ 3358 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.510913 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.542079 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:25.956367 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.001702 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:26.177734 [ 2994 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.225072 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:26.240789 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.419711 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.513775 [ 3051 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.547936 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:26.965604 [ 3164 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.042886 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:27.180537 [ 3085 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.243341 [ 3012 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.400137 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:27.423041 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.516491 [ 3217 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.550305 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:27.968155 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.143278 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:28.182762 [ 3109 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.245376 [ 3455 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.337755 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:28.431709 [ 3060 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.518747 [ 3364 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.557889 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:28.969978 [ 3345 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.047821 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:29.267024 [ 3082 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.267207 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.279313 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:29.433489 [ 3371 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.520988 [ 3016 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.560277 [ 3395 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:29.971502 [ 3449 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.045215 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:30.167159 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:30.269264 [ 3425 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.273588 [ 3069 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.435164 [ 3073 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.522937 [ 3050 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.565653 [ 3113 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:30.957656 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:30.973543 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.185464 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:31.271687 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.275941 [ 3182 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.437289 [ 2966 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.525179 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.568098 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:31.975958 [ 3245 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.010577 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:32.274403 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.278488 [ 3477 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.289092 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:32.439824 [ 3244 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.527862 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.576275 [ 3117 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:32.980005 [ 3031 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.173200 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:33.277448 [ 3387 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.284088 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.395013 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:33.444233 [ 3221 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.518734 [ 3595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bb3dcfd6-a01b-47b1-9aaf-cf887b88b4e1::202509_105_145_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.536536 [ 3331 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.579423 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:33.981723 [ 3217 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.279901 [ 2984 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.286982 [ 3211 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.287462 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:34.430768 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:34.447540 [ 3250 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.541117 [ 3336 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.585922 [ 3488 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:34.984333 [ 3234 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.282411 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.289321 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.388986 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:35.449336 [ 3421 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.458557 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:35.544030 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.591434 [ 3122 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:35.986927 [ 2996 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.284994 [ 2968 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.291376 [ 3094 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.454062 [ 3444 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.546458 [ 3378 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.576478 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:36.578436 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:36.593471 [ 3146 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:36.996829 [ 3184 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:37.287177 [ 3229 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:37.293019 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:37.508753 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:37.509820 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:37.536487 [ 3265 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:37.562446 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:37.595651 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.014545 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.289369 [ 3239 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.295049 [ 3131 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.471929 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:38.538698 [ 2983 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.567418 [ 2967 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.600438 [ 3174 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:38.611589 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:39.016369 [ 3027 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.290667 [ 4816 ] {489a881a-7cb9-457c-bb25-fb81baeada46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:54870) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:39.294245 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.294533 [ 4816 ] {489a881a-7cb9-457c-bb25-fb81baeada46} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:23:39.297238 [ 3323 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.553609 [ 3287 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.569935 [ 3285 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.602258 [ 2995 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:39.632896 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:39.735188 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:40.018182 [ 3362 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.296910 [ 3416 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.300395 [ 3032 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.555987 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.572122 [ 3013 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.610940 [ 3185 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:40.780336 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:40.800011 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:41.020464 [ 3071 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.299840 [ 3173 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.302908 [ 3223 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.558585 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.575017 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.613519 [ 2965 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:41.855462 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:41.883357 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:42.023412 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.356995 [ 3087 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.396928 [ 3033 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.564060 [ 2985 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.577673 [ 3412 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.616835 [ 3011 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:42.867428 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:42.893853 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:43.026544 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.359733 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.402371 [ 3261 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.580517 [ 3281 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.624347 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.566954 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:43.996654 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:44.030182 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:44.031959 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:44.366371 [ 3314 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:44.405284 [ 3151 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:44.583054 [ 3227 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:44.626345 [ 3099 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:44.693513 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.034379 [ 3469 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.126857 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:45.206829 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_98_170_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.219656 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:45.369152 [ 3220 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.465970 [ 3409 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.585720 [ 3122 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.628703 [ 3311 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:45.696457 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.037576 [ 3296 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.360935 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:46.370926 [ 3199 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.540559 [ 3389 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.588110 [ 3149 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.631949 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:46.765893 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.046802 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.373433 [ 3058 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.417985 [ 7604 ] {9332c3bc-857f-439e-909a-2e2170140d29} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53270) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT UUIDStringToNum('00112233-4455-6677-8899-aabbccddeeff', materialize(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:23:47.422552 [ 7604 ] {9332c3bc-857f-439e-909a-2e2170140d29} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:23:47.545159 [ 3268 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.590444 [ 3337 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.608028 [ 4816 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:47.634701 [ 3360 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:47.743279 [ 7604 ] {850cc565-ecb3-490a-b3cf-697d92cd20e3} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53270) (comment: 03095_msan_uuid_string_to_num.sql) (in query: SELECT 'a/<@];!~p{jTj={)' AS bytes, UUIDNumToString(toFixedString(bytes, 16), materialize(2)) AS uuid;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:23:47.745608 [ 7604 ] {850cc565-ecb3-490a-b3cf-697d92cd20e3} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000010fcb9e1 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fca9f4 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad512 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x0000000013140694 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c4fba 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>>&) @ 0x0000000011654afc 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164ef6a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:23:47.768606 [ 2964 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.059225 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.376215 [ 3355 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.547981 [ 3336 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.592858 [ 3146 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.638103 [ 3081 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.771259 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:48.922606 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:49.061806 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:49.379018 [ 3115 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:49.553559 [ 2991 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:49.594339 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:49.640605 [ 2969 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:49.773917 [ 2974 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.065631 [ 3171 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.078099 [ 79578 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:50.382408 [ 3416 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.556629 [ 3265 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.596663 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.645838 [ 3215 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:50.776905 [ 3098 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.067725 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.258831 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:51.391062 [ 3392 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.559196 [ 3395 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.598944 [ 2967 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.651673 [ 3287 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:51.782582 [ 3193 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.070137 [ 3014 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.397699 [ 2966 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.428182 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:52.566645 [ 3113 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.604387 [ 3354 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.657301 [ 3001 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:52.788423 [ 2977 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.072698 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.403334 [ 3068 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.536887 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:53.569028 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.606970 [ 2995 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.659699 [ 3440 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:53.790403 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.075283 [ 3263 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.432315 [ 3173 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.571485 [ 3126 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.619624 [ 3358 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.663236 [ 3289 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:54.734538 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:54.793063 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.080621 [ 3026 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.435402 [ 3313 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.573791 [ 3102 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.622244 [ 3258 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.666058 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:55.795978 [ 3212 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.023315 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:56.082316 [ 3161 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.437308 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.578232 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.624137 [ 2988 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.671542 [ 2994 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:56.801132 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.045426 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:57.086748 [ 3405 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.439448 [ 3253 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.581641 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.626286 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.673595 [ 3222 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:57.803731 [ 3055 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.089011 [ 3190 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.172522 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:58.442402 [ 3059 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.583823 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.629183 [ 3303 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.676131 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:58.806316 [ 3431 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.091807 [ 3238 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.157770 [ 4905 ] {cac2952d-dae2-4bd5-9287-c0bfffce571d} executeQuery: Code: 57. DB::Exception: Table test_0bwr8lfy.src already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50678) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: CREATE TABLE src (`p` UInt64, `k` String, `d` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY k SETTINGS index_granularity = 20626, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 65, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 296991540, compact_parts_max_granules_to_buffer = 66, compact_parts_merge_max_bytes_to_prefetch_part = 12178280, merge_max_block_size = 5971, old_parts_lifetime = 281., 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 = 4183213004, index_granularity_bytes = 20732763, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 60253, primary_key_compress_block_size = 10292), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:23:59.161517 [ 4905 ] {cac2952d-dae2-4bd5-9287-c0bfffce571d} TCPHandler: Code: 57. DB::Exception: Table test_0bwr8lfy.src 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:23:59.407981 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:23:59.446221 [ 3042 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.589267 [ 3488 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.631896 [ 3155 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.678798 [ 3341 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:23:59.812276 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.097217 [ 3370 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.461515 [ 3040 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.591879 [ 3149 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.684420 [ 3017 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.689486 [ 3154 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:00.691044 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:00.814090 [ 3332 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.099905 [ 3205 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.470405 [ 3272 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.633405 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.688506 [ 3366 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.692447 [ 3447 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.819228 [ 3359 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:01.844439 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:02.102268 [ 3481 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:02.476226 [ 3419 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:02.636302 [ 2989 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:02.691055 [ 3451 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:02.694909 [ 3240 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:02.821532 [ 2988 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.105258 [ 3086 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.135541 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:03.482574 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.645531 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.694719 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.697076 [ 3487 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:03.823840 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.107709 [ 3039 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.182597 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:04.485425 [ 3029 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.649078 [ 3271 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.697545 [ 3142 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.705992 [ 3301 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:04.829247 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.101308 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:05.109353 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.488802 [ 3018 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.651616 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.708377 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.710292 [ 3430 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:05.835456 [ 3310 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.111891 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.268715 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:06.492208 [ 3202 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.654205 [ 3413 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.711044 [ 2970 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.712760 [ 3260 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:06.840748 [ 3243 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.114351 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.495040 [ 3249 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.506341 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:07.656524 [ 3458 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.714264 [ 3038 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.769847 [ 2990 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:07.850250 [ 3051 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.116802 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.510142 [ 3152 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.662911 [ 3440 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.716461 [ 2976 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.722211 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:08.772331 [ 2977 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:08.853088 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.122516 [ 3350 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.513325 [ 3147 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.666174 [ 3013 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.718688 [ 3089 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.774838 [ 3028 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:09.908400 [ 3075 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.003862 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:10.127562 [ 3464 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.516523 [ 3364 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.668124 [ 3325 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.722440 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.748164 [ 3594 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bb3dcfd6-a01b-47b1-9aaf-cf887b88b4e1::202509_105_150_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.780150 [ 3367 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:10.914199 [ 2987 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.133917 [ 3391 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.144295 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:11.518896 [ 4770 ] {c9c88cac-170e-4a02-9dc3-0eb3dd10ca95} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02517_executable_pool_bad_input_query.sql) (in query: /* ddl_entry=query-0000000111 */ CREATE TABLE test_5.test_table UUID '4a08a53c-5a48-4ca9-b150-71e61cc1da4e' (`value` String) ENGINE = ExecutablePool('nonexist.py', 'TabSeparated', foobar)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:24:11.519375 [ 3181 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.575615 [ 4770 ] {c9c88cac-170e-4a02-9dc3-0eb3dd10ca95} executeQuery: Code: 57. DB::Exception: Table test_5.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52638) (comment: 02517_executable_pool_bad_input_query.sql) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', (foobar));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:24:11.577883 [ 4770 ] {c9c88cac-170e-4a02-9dc3-0eb3dd10ca95} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f2b1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115583da 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111644fc 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000001116291e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e09298 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de91a6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558243 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000115622f2 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:24:11.670527 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.727074 [ 3262 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.797496 [ 3144 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:11.918821 [ 3303 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.136353 [ 3140 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.197369 [ 4905 ] {8a70221f-847f-4ce1-a53a-cd1b8b43749a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52650) (comment: 01913_names_of_tuple_literal.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:12.224865 [ 4905 ] {8a70221f-847f-4ce1-a53a-cd1b8b43749a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000108857b3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9849 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a38ca 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:12.267917 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:12.523116 [ 3466 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.673131 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.732341 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.799727 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:12.921612 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.138779 [ 3435 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.433274 [ 3587 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {da4b0f46-cb5e-4c3c-b2a1-86ffeaae2bb8::202509_190_195_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.474704 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:13.525534 [ 3237 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.675589 [ 3404 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.738527 [ 3233 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.802071 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:13.923977 [ 3112 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.157549 [ 3186 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.528753 [ 3148 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.677942 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.701451 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:14.740638 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.805708 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:14.926127 [ 3299 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.160253 [ 3279 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.534096 [ 3192 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.683503 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.743003 [ 3128 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.779979 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:15.810805 [ 3368 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:15.928464 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.165102 [ 3369 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.324395 [ 4905 ] {d3e3286e-9e74-4db0-bd6a-6d32ee6e5c98} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:52676) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: insert into t2 select number 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:24:16.371497 [ 4905 ] {d3e3286e-9e74-4db0-bd6a-6d32ee6e5c98} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:24:16.537012 [ 3389 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.686113 [ 3366 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.752315 [ 3045 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.817496 [ 3422 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.931367 [ 3047 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:16.978477 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:17.168270 [ 3233 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.540432 [ 3052 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.688931 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.754961 [ 3256 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.820133 [ 3088 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.933842 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:17.968987 [ 4770 ] {626cee22-06c3-4272-8713-1aea4404d135} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a') AND ((rand() % 100) < 20). (ILLEGAL_PREWHERE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58346) (comment: 01915_merge_prewhere_virtual_column_rand_chao_wang.sql) (in query: -- In version 20.12 this query sometimes produces an exception "Cannot find column" SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE _table = 'abc' AND f1 = 'a' AND rand() % 100 < 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f4f0 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000001109d730 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164be55 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:17.972092 [ 4770 ] {626cee22-06c3-4272-8713-1aea4404d135} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a') AND ((rand() % 100) < 20). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f4f0 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000001109d730 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164be55 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:18.176775 [ 3170 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:18.196956 [ 4770 ] {40661c9c-d32e-4229-8174-acac05cab493} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a'). (ILLEGAL_PREWHERE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58346) (comment: 01915_merge_prewhere_virtual_column_rand_chao_wang.sql) (in query: SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE _table = 'abc' AND f1 = '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f4f0 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000001109d730 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164be55 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:18.215384 [ 4770 ] {40661c9c-d32e-4229-8174-acac05cab493} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a'). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f4f0 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000001109f0db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000001109d730 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164be55 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164864d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001191074d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:18.256158 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:18.546885 [ 3268 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:18.691343 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:18.757475 [ 3255 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:18.825715 [ 3347 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:18.936531 [ 3055 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.178705 [ 3109 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.218965 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:19.549180 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.693607 [ 3434 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.760452 [ 3167 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.832046 [ 3153 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.917132 [ 76100 ] {697e3eb6-24cb-4c78-af42-6f66de0bd695} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:49046) (comment: 00502_sum_map.sql) (in query: DROP DATABASE IF EXISTS test_qh2b81qg ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:24:19.918684 [ 76100 ] {697e3eb6-24cb-4c78-af42-6f66de0bd695} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:19.943304 [ 3130 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.181221 [ 3463 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.215458 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:20.551657 [ 3299 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.695883 [ 3451 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.763059 [ 3132 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.834264 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:20.944893 [ 3374 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.097717 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:21.184588 [ 3317 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.559303 [ 3395 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.698314 [ 3487 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.765856 [ 3376 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.836959 [ 3390 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:21.951911 [ 3138 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.190187 [ 3307 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.241694 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:22.561600 [ 2982 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.700750 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.768860 [ 2970 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.841923 [ 3456 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:22.956330 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.165906 [ 79578 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:23.192286 [ 3443 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.570515 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.704099 [ 3142 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.774857 [ 2964 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.844663 [ 2985 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:23.958746 [ 3445 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.194413 [ 3026 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.232381 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:24.572652 [ 3154 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.706325 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.776731 [ 2976 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.847438 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:24.960649 [ 3411 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:25.200313 [ 3246 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:25.302266 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:25.580625 [ 3354 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:25.709156 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:25.779986 [ 3168 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:25.849472 [ 3476 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.008824 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.135743 [ 7898 ] {4fa5471b-f084-4a95-861c-717efeb83ad3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51244) (comment: 01890_materialized_distributed_join.sh) (in query: SELECT sum(`__table2`.`v`) AS `sum(tl.v)` FROM `test_5`.`test_shard` AS `__table1` ASOF INNER JOIN `test_5`.`test_local` AS `__table2` ON (`__table1`.`k` = `__table2`.`k`) AND (`__table1`.`v` < `__table2`.`v`) GROUP BY `__table1`.`k`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:24:26.159409 [ 7898 ] {4fa5471b-f084-4a95-861c-717efeb83ad3} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:24:26.202474 [ 3092 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.310345 [ 4770 ] {fd286d77-9b45-492b-9347-39259fac89b2} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58396) (comment: 01890_materialized_distributed_join.sh) (in query: select sum(tl.v) from test_distributed td asof join test_5.test_local tl on td.k = tl.k and td.v < tl.v group by td.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:26.317179 [ 4665 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34686, 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.318313 [ 4770 ] {fd286d77-9b45-492b-9347-39259fac89b2} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:26.362575 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:26.590498 [ 3287 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.711160 [ 3429 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.781407 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:26.852938 [ 3063 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.011863 [ 3296 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.206920 [ 3182 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.292198 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:27.377230 [ 76521 ] {03fab104-de7c-49a0-bcea-c696e3e1ae7f} executeQuery: Code: 81. DB::Exception: Database _table_function does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:58446) (comment: 01913_exact_rows_before_limit_full.sql) (in query: select * from (select * from cluster(test_cluster_two_shards, currentDatabase(), test) where i < 10) order by i limit 1 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::getDatabase(String const&) const @ 0x000000001117a475 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fca38 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089645 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046f9c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e9e6 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584b94 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000011584a42 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&) @ 0x0000000011647623 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 19. /build/contrib/llvm-project/libcxx/include/vector:438: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000001317241d 20. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1c8a8 21. /build/src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000001165d31d 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d8ab 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000011649350 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116461c6 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:24:27.386639 [ 76521 ] {03fab104-de7c-49a0-bcea-c696e3e1ae7f} TCPHandler: Code: 81. DB::Exception: Database _table_function 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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::getDatabase(String const&) const @ 0x000000001117a475 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fca38 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089645 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046f9c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e9e6 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584b94 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000011584a42 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&) @ 0x0000000011647623 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 19. /build/contrib/llvm-project/libcxx/include/vector:438: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000001317241d 20. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000011e1c8a8 21. /build/src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000001165d31d 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d8ab 23. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a45e 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000011649350 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116461c6 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&) @ 0x0000000011648a44 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 2025.09.25 21:24:27.592410 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.713028 [ 3274 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.782857 [ 3280 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:27.854613 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.014197 [ 3384 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.209121 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.281153 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:28.594040 [ 3482 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.714447 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.823746 [ 3477 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:28.862056 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.015788 [ 3223 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.113325 [ 4770 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:29.211271 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.217564 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:29.597962 [ 3149 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.691623 [ 76521 ] {322974b4-35d3-4f76-943b-23753c0cc404} executeQuery: Code: 60. DB::Exception: Table test_5.nbagames does not exist. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36616) (comment: 01825_type_json_nbagames.sh) (in query: INSERT INTO nbagames FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:29.715784 [ 76521 ] {322974b4-35d3-4f76-943b-23753c0cc404} TCPHandler: Code: 60. DB::Exception: Table test_5.nbagames 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:29.716501 [ 3300 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.825983 [ 3359 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:29.864775 [ 3390 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.022544 [ 3104 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.213895 [ 2981 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.250064 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:30.282476 [ 4665 ] {c81d671a-460c-4c35-b277-6623bd6f9a33} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT count() FROM nbagames WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36640) (comment: 01825_type_json_nbagames.sh) (in query: SELECT count() FROM nbagames WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:30.296071 [ 4665 ] {c81d671a-460c-4c35-b277-6623bd6f9a33} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT count() FROM nbagames WHERE NOT ignore(*). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:30.600808 [ 3020 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.718664 [ 3267 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.831989 [ 3025 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.867066 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:30.878850 [ 76521 ] {1f41dc5b-6fe4-4cef-bb9f-e9be8cb9f398} executeQuery: Code: 60. DB::Exception: Table test_5.nbagames does not exist. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36672) (comment: 01825_type_json_nbagames.sh) (in query: DESC nbagames SETTINGS describe_extend_object_types = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterDescribeQuery.cpp:174: DB::InterpreterDescribeQuery::fillColumnsFromTable(DB::ASTTableExpression const&) @ 0x000000001195e5a0 8. /build/src/Interpreters/InterpreterDescribeQuery.cpp:97: DB::InterpreterDescribeQuery::execute() @ 0x000000001195d265 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:30.894540 [ 76521 ] {1f41dc5b-6fe4-4cef-bb9f-e9be8cb9f398} TCPHandler: Code: 60. DB::Exception: Table test_5.nbagames 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /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 @ 0x0000000010e17fa9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterDescribeQuery.cpp:174: DB::InterpreterDescribeQuery::fillColumnsFromTable(DB::ASTTableExpression const&) @ 0x000000001195e5a0 8. /build/src/Interpreters/InterpreterDescribeQuery.cpp:97: DB::InterpreterDescribeQuery::execute() @ 0x000000001195d265 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:31.031538 [ 3401 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:31.215757 [ 3443 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:31.501708 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:31.551663 [ 4665 ] {27839b37-3268-48a4-bcb0-502900957d71} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36694) (comment: 01825_type_json_nbagames.sh) (in query: SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:31.563960 [ 4665 ] {27839b37-3268-48a4-bcb0-502900957d71} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 5. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:24:31.614212 [ 3175 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:31.720790 [ 3129 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:31.834655 [ 3088 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:31.873994 [ 3243 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.034224 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.220191 [ 3295 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.271868 [ 4770 ] {b0ae297c-9952-4d4e-b890-a1218a6cb7be} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT arrayJoin(arrayJoin(data.teams.players)) AS players FROM nbagames. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36712) (comment: 01825_type_json_nbagames.sh) (in query: SELECT player, sum(triple_double) AS triple_doubles FROM ( SELECT tupleElement(players, 'player') AS player, ((tupleElement(players, 'pts') >= 10) + (tupleElement(players, 'ast') >= 10) + (tupleElement(players, 'blk') >= 10) + (tupleElement(players, 'stl') >= 10) + (tupleElement(players, 'trb') >= 10)) >= 3 AS triple_double FROM ( SELECT arrayJoin(arrayJoin(data.teams.players)) as players from nbagames ) ) GROUP BY player ORDER BY triple_doubles DESC, player LIMIT 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:24:32.293300 [ 4770 ] {b0ae297c-9952-4d4e-b890-a1218a6cb7be} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT arrayJoin(arrayJoin(data.teams.players)) AS players FROM nbagames. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060144 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 27. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:24:32.504330 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:32.550317 [ 76521 ] {e91dd004-f685-4800-8b70-69836ef40341} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47552) (comment: 02149_read_in_order_fixed_prefix.sql) (in query: SELECT `__table1`.`date` AS `date`, `__table1`.`i` AS `i` FROM `test_2ktfz6jy`.`t_read_in_order` AS `__table1` WHERE `__table1`.`date` = '2020-10-11' ORDER BY `__table1`.`i` ASC LIMIT _CAST(5, '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:104: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d494d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:24:32.558275 [ 76521 ] {e91dd004-f685-4800-8b70-69836ef40341} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:104: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d494d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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.09.25 21:24:32.585659 [ 77647 ] {4d6ad41b-2fed-4d2f-9ac4-d2c8c6c06b30} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:104: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d494d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36534) (comment: 02149_read_in_order_fixed_prefix.sql) (in query: SELECT date, i FROM t_read_in_order WHERE date = '2020-10-11' ORDER BY i LIMIT 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:32.591442 [ 4770 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57054, local: [::ffff:127.0.0.10]: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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cb4a30 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 12. ? @ 0x00007fd96814bac3 13. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.593451 [ 77647 ] {4d6ad41b-2fed-4d2f-9ac4-d2c8c6c06b30} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f7e21 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&) @ 0x00000000128f85bc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4ca2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd4faf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6224 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) @ 0x00000000128f5f4c 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&) @ 0x000000001282d934 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 @ 0x000000001282a6ee 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b472e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:104: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d494d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fd0c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d6ddea 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 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:32.616294 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.726457 [ 3128 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.837272 [ 3347 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:32.877154 [ 3231 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.036725 [ 3322 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.224540 [ 3112 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.618525 [ 3264 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.701821 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:33.728772 [ 3293 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.842667 [ 2999 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:33.880096 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.043148 [ 3328 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.227427 [ 3204 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.280024 [ 4665 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:34.620663 [ 3373 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.730507 [ 3167 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.821083 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:34.845018 [ 3480 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:34.882668 [ 3135 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.045649 [ 3178 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.231150 [ 3326 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.627141 [ 3311 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.739995 [ 3376 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.847048 [ 3310 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.888673 [ 2985 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:35.980874 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:36.051410 [ 3027 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.111223 [ 4665 ] {b406aa35-1856-4104-adf0-3f37f5f1a1a5} executeQuery: Code: 60. DB::Exception: Table test_5.nbagames_from_string does not exist. Maybe you meant test_5.nbagames_string?. (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36800) (comment: 01825_type_json_nbagames.sh) (in query: INSERT INTO nbagames_from_string SELECT data FROM nbagames_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:36.147802 [ 4665 ] {b406aa35-1856-4104-adf0-3f37f5f1a1a5} TCPHandler: Code: 60. DB::Exception: Table test_5.nbagames_from_string does not exist. Maybe you meant test_5.nbagames_string?. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/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 @ 0x0000000010e180e2 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111760ac 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c007 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f47ef 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:36.233535 [ 3356 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.629302 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.741744 [ 3203 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.849083 [ 3398 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.873213 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:36.891001 [ 3028 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:36.914364 [ 4770 ] {35b64c08-5ff2-41f3-aef4-0c81b9140922} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string). (UNKNOWN_TABLE) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38058) (comment: 01825_type_json_nbagames.sh) (in query: SELECT (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string) = (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c664 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:24:36.930401 [ 4770 ] {35b64c08-5ff2-41f3-aef4-0c81b9140922} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string). (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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&) @ 0x000000001105f591 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110323d9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038d6f 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c664 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:24:37.054144 [ 3362 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.236125 [ 3453 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.631803 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.743504 [ 2964 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.850973 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.893121 [ 3348 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:37.972727 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:38.056456 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.238240 [ 3425 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.419631 [ 7898 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.634929 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.746068 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.853448 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:38.896028 [ 3012 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.061965 [ 3205 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.155175 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:39.240534 [ 3120 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.637228 [ 3388 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.748946 [ 3450 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.856272 [ 3304 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:39.907664 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.065911 [ 3171 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.242796 [ 3308 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.264818 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:40.640255 [ 3097 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.752016 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.858381 [ 3274 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:40.909940 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.075772 [ 3077 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.245514 [ 3314 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.416954 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:41.518619 [ 3615 ] {} test_0bwr8lfy.dst_r2 (cdee8cfc-04b5-497f-8a27-f14c783d05e6): Part 1_23_23_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.09.25 21:24:41.643164 [ 3185 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.753804 [ 3414 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.860664 [ 3350 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:41.922848 [ 3140 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.078251 [ 3392 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.265169 [ 3105 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.529337 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:42.645446 [ 3242 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.756227 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.863236 [ 3382 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:42.937394 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.081026 [ 3010 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.266926 [ 3082 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.650710 [ 3287 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.684887 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:43.759747 [ 3255 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.866043 [ 2975 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:43.940199 [ 3304 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.110494 [ 3044 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.269319 [ 3257 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.653163 [ 3271 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.765553 [ 3430 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.838891 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:44.876053 [ 3064 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:44.947010 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.113667 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.275590 [ 3453 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.288564 [ 4770 ] {50811890-4fe9-49fc-a104-d06c0ad35208} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38342) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:45.292475 [ 4770 ] {50811890-4fe9-49fc-a104-d06c0ad35208} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:45.659090 [ 3283 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.768361 [ 2970 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.878397 [ 3454 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:45.928990 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:45.949827 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.116426 [ 3077 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.270156 [ 76102 ] {9d9a3b8e-8342-47c8-ac7d-c18d911a0570} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58876) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (in query: SELECT count() AS `count()`, sum(`__table1`.`d`) AS `sum(d)` FROM `test_rccfr2ji`.`dst_r2` 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:46.272666 [ 76102 ] {9d9a3b8e-8342-47c8-ac7d-c18d911a0570} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:46.278618 [ 3069 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.317464 [ 4770 ] {03dc6220-36f8-49ae-8c71-9ae8b25d9366} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:38388) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (in query: SELECT count(), sum(d) FROM dst_r2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:46.324586 [ 4770 ] {03dc6220-36f8-49ae-8c71-9ae8b25d9366} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=748). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 : 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) @ 0x00000000164833b2 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 @ 0x0000000012bbebc9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc548d 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfcb5f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fae3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f1d2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f01a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1ed41 2025.09.25 21:24:46.391079 [ 7898 ] {ed8e74ef-7bbd-4d7b-83fc-4acb786d002e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:59436) (comment: 00626_replace_partition_from_table_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_0bwr8lfy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:24:46.391973 [ 8202 ] {17512e6b-6d8f-4658-9320-b91771c9395c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:36746). (NETWORK_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36746) (comment: 02864_replace_partition_with_duplicated_parts_zookeeper.sh) (in query: SELECT count() AS `count()`, sum(`__table1`.`d`) AS `sum(d)` FROM `test_rccfr2ji`.`dst_r2` 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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:24:46.394739 [ 7898 ] {ed8e74ef-7bbd-4d7b-83fc-4acb786d002e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.394798 [ 8202 ] {17512e6b-6d8f-4658-9320-b91771c9395c} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:36746). (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) @ 0x00000000164833b2 1. /build/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() @ 0x0000000012cc029a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5326 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 2025.09.25 21:24:46.405148 [ 8202 ] {17512e6b-6d8f-4658-9320-b91771c9395c} TCPHandler: Client has gone away. 2025.09.25 21:24:46.662332 [ 2995 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.770841 [ 3067 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.883851 [ 3226 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:46.955664 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.119329 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.180257 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:47.281490 [ 3110 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.665068 [ 3097 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.775343 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.889883 [ 3072 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:47.957742 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.122064 [ 3169 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.143421 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:48.283590 [ 3190 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.667796 [ 3166 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.781849 [ 3038 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.892430 [ 3070 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:48.960347 [ 3144 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.125353 [ 3482 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.198658 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:49.285356 [ 3316 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.670488 [ 3325 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.784407 [ 2990 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.894663 [ 2993 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:49.962973 [ 3320 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.127637 [ 3457 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.260809 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:50.295692 [ 3078 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.673039 [ 3452 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.789451 [ 3127 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.805093 [ 76521 ] {deee48a7-49d3-4b9e-9041-23a5026016ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=745). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41100) (comment: 02099_tsv_raw_format_1.sh) (in query: INSERT INTO test_02099 SELECT number, toString(number), toDate(number) FROM numbers(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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:24:50.820236 [ 76521 ] {deee48a7-49d3-4b9e-9041-23a5026016ec} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=745). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d5e661 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb577f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 14. ? @ 0x00007fd96814bac3 15. ? @ 0x00007fd9681dd850 2025.09.25 21:24:50.897265 [ 3446 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:50.966657 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.162697 [ 3111 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.301642 [ 3054 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.441583 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:51.678821 [ 3277 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.794326 [ 2976 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.899343 [ 3121 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:51.969735 [ 3100 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.165026 [ 3233 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.304114 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.655733 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:52.681804 [ 3056 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.801836 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.903155 [ 3210 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:52.975762 [ 3449 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.173272 [ 3312 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.305976 [ 3361 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.684985 [ 3487 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.721136 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:53.804411 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.905854 [ 3075 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:53.978642 [ 3349 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.175963 [ 3116 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.308397 [ 3015 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.687868 [ 3267 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.814650 [ 3403 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.908376 [ 3397 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:54.955785 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:54.981480 [ 3031 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.180129 [ 3046 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.311066 [ 3327 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.512100 [ 76521 ] {7d2a2eac-301d-4e6f-b0ec-82edfe7ad0f1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41248) (comment: 02563_arrow_low_cardinality_bug.sh) (in query: select CAST(number % 2 ? NULL : toString(number), 'LowCardinality(Nullable(String))') as z from numbers(2) format Arrow settings output_format_arrow_low_cardinality_as_dictionary=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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:55.539989 [ 76521 ] {7d2a2eac-301d-4e6f-b0ec-82edfe7ad0f1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:24:55.690798 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.817836 [ 3422 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.914260 [ 2978 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:55.995593 [ 3483 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.185719 [ 3246 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.226925 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:56.313729 [ 3165 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.696989 [ 3091 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.839526 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.916399 [ 3479 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:56.997679 [ 3184 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.192789 [ 3455 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.213021 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:57.319699 [ 3003 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.669744 [ 76521 ] {2ef05549-2557-423b-a5b4-e3be6af76371} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:42990) (comment: 02473_functions_in_readonly_mode.sh) (in query: SELECT * from format('TSV', '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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x00000000107da8f8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d98c5 6. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 8. /build/src/TableFunctions/ITableFunction.cpp:33: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c0e2b 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:24:57.676587 [ 76521 ] {2ef05549-2557-423b-a5b4-e3be6af76371} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x00000000107da8f8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d98c5 6. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 8. /build/src/TableFunctions/ITableFunction.cpp:33: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c0e2b 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7772 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d504 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601c1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 28. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 2025.09.25 21:24:57.700887 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.842194 [ 3398 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.924676 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:57.999780 [ 3261 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:58.206792 [ 3405 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:58.325139 [ 3238 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:58.327027 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:58.513745 [ 8202 ] {3be11227-30ec-4192-a8e7-169c4bcc8478} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:43040) (comment: 02473_functions_in_readonly_mode.sh) (in query: INSERT INTO FUNCTION null('x String') (x) 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x00000000107da8f8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d98c5 6. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 8. /build/src/TableFunctions/ITableFunction.cpp:33: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c0e2b 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:116: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f45f7 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:24:58.536687 [ 8202 ] {3be11227-30ec-4192-a8e7-169c4bcc8478} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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 @ 0x00000000107da8f8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d98c5 6. /build/src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x00000000107c58d9 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x00000000110e13e6 8. /build/src/TableFunctions/ITableFunction.cpp:33: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c0e2b 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:116: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f45f7 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb3f5 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 19. ? @ 0x00007fd96814bac3 20. ? @ 0x00007fd9681dd850 2025.09.25 21:24:58.704092 [ 2994 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:58.845446 [ 3028 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:58.927595 [ 3367 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.035805 [ 3328 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.213239 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.327264 [ 3309 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.484150 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:24:59.710087 [ 3011 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.847886 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:24:59.933128 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.039403 [ 3178 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.215780 [ 3151 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.335977 [ 3223 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.645779 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:00.711891 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.849775 [ 3450 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:00.935133 [ 3473 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.041590 [ 3478 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.225260 [ 3139 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.337908 [ 3252 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.569907 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:01.713885 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.851817 [ 3433 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:01.937355 [ 3148 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.047632 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.227788 [ 3266 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.340105 [ 3327 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.635401 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:02.715971 [ 3240 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.863214 [ 3480 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:02.942384 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.052277 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.234659 [ 3046 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.341911 [ 3030 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.563690 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:03.723356 [ 3142 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.867572 [ 2975 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:03.944594 [ 3130 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.054860 [ 3362 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.237601 [ 3418 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.252078 [ 76102 ] {682529d9-0fdd-4ade-9c82-5deeb182ab3e} 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.10508.altinitytest (altinity build)) (from [::1]:43234) (comment: 02125_lz4_compression_bug_TSKV.sh) (in query: INSERT INTO file SELECT * 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:25:04.333931 [ 76102 ] {682529d9-0fdd-4ade-9c82-5deeb182ab3e} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012d61579 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fcd4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f725 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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 14. ? @ 0x00007fd9681dd850 2025.09.25 21:25:04.344620 [ 3165 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.725878 [ 3009 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.874754 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.949053 [ 2997 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:04.987775 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:05.063538 [ 3071 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:05.240427 [ 3065 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:05.347817 [ 3003 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:05.732944 [ 3158 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:05.878339 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:05.955679 [ 3262 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.069006 [ 3141 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.188283 [ 76102 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:06.283485 [ 3316 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.350382 [ 3238 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.735782 [ 3128 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.883082 [ 3226 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:06.959638 [ 3163 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.071425 [ 3010 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.161758 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:07.285490 [ 3477 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.352473 [ 3259 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.737799 [ 3045 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.885663 [ 3247 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:07.962141 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.073993 [ 3160 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.181835 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:08.289919 [ 3120 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.354832 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.751517 [ 3301 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.893560 [ 2993 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:08.965086 [ 3320 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.079935 [ 3370 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.197482 [ 8202 ] {d30ebe8b-4117-46bf-926e-977721cdb44f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50302) (comment: 01948_dictionary_quoted_database_name.sql) (in query: DROP DICTIONARY `01945.db`.`test_dictionary.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:09.215176 [ 8202 ] {d30ebe8b-4117-46bf-926e-977721cdb44f} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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>&) @ 0x0000000011573604 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000115714f4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570c70 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:09.294974 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:09.300271 [ 2984 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.398610 [ 3380 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.754801 [ 3256 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.896168 [ 3446 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:09.968202 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:10.090154 [ 3427 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:10.303255 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:10.403016 [ 3151 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:10.418913 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:10.761492 [ 3189 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:10.905207 [ 3456 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.001871 [ 3245 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.092868 [ 3000 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.305638 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.405961 [ 3409 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.576237 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:11.826779 [ 3132 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:11.909000 [ 3397 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.004628 [ 3280 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.098004 [ 3044 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.308510 [ 3254 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.411824 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.791865 [ 4770 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:12.841116 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:12.912312 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.020414 [ 3104 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.106389 [ 3306 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.310820 [ 2968 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.414168 [ 3191 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.843980 [ 3347 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.916055 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:13.982456 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:14.022609 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:14.108973 [ 3136 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:14.313119 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:14.416560 [ 3318 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:14.846671 [ 2999 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:14.921023 [ 3439 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.026621 [ 2998 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.111337 [ 3350 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.126825 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:15.318911 [ 3015 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.418773 [ 3489 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.849248 [ 3080 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:15.931517 [ 3222 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.028652 [ 3321 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.113930 [ 3096 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.322109 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.335258 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:16.421276 [ 3042 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.930096 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:16.934078 [ 2987 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.032666 [ 3381 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.116751 [ 3108 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.324991 [ 3431 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.427747 [ 3057 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.602455 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:17.934009 [ 3055 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:17.936082 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.034896 [ 3270 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.122714 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.330782 [ 3305 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.430360 [ 3444 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.631145 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:18.936387 [ 3342 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:18.940334 [ 3218 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.037030 [ 3478 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.125363 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.333454 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.432677 [ 3448 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.844958 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:19.939218 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:19.951079 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.039394 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.128152 [ 3272 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.336369 [ 3330 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.437983 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.944775 [ 3411 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:20.953791 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.035775 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:21.042012 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.131456 [ 3248 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.339019 [ 2991 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.440963 [ 3378 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.947388 [ 2996 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:21.959891 [ 3303 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.044383 [ 3117 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.136881 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.170059 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:22.341702 [ 3471 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.445988 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.954620 [ 3216 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:22.963381 [ 3274 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.046807 [ 3429 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.200742 [ 3465 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.250478 [ 76521 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:23.344377 [ 3367 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.455409 [ 3421 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.777142 [ 7604 ] {4ac61b5b-31b6-4a30-8505-59822a762f77} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33782) (comment: 02125_lz4_compression_bug_TSKV.sh) (in query: INSERT INTO file SELECT * FROM numbers(2500000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb16c5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0704 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000012eb239a 10. /build/src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::finalize() @ 0x0000000012d76162 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::StorageFileSink::finalizeBuffers() @ 0x000000001226db15 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facb9c 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 17. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 18. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 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. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:25:23.847440 [ 7604 ] {4ac61b5b-31b6-4a30-8505-59822a762f77} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000012eb16c5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0704 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000012eb239a 10. /build/src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::finalize() @ 0x0000000012d76162 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::StorageFileSink::finalizeBuffers() @ 0x000000001226db15 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012facfdf 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facb9c 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 17. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 18. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 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. ? @ 0x00007fd96814bac3 23. ? @ 0x00007fd9681dd850 2025.09.25 21:25:23.961026 [ 3163 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:23.967038 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.049677 [ 3178 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.207181 [ 3317 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.333672 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:24.346992 [ 3030 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.462860 [ 3173 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.964856 [ 3144 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:24.972555 [ 3345 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.052415 [ 3027 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.209750 [ 3393 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.355498 [ 3340 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.369057 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:25.468438 [ 3419 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.961147 [ 7604 ] {f2f741b4-32eb-4266-b797-e87d51e3288c} executeQuery: Code: 33. DB::Exception: Unexpected end of stream after field in TSKV format: x: (at row 2313121) : (in file/uri /var/lib/clickhouse/user_files/test_z4t0odqr/data.TSKV.lz4): While executing TSKVRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:33820) (comment: 02125_lz4_compression_bug_TSKV.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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/TSKVRowInputFormat.cpp:0: DB::TSKVRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012f51ab1 5. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 6. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 7. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 11. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 13. /build/src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000001225e540 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 19. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:25:25.967094 [ 3164 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:25.974564 [ 3449 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.000304 [ 7604 ] {f2f741b4-32eb-4266-b797-e87d51e3288c} TCPHandler: Code: 33. DB::Exception: Unexpected end of stream after field in TSKV format: x: (at row 2313121) : (in file/uri /var/lib/clickhouse/user_files/test_z4t0odqr/data.TSKV.lz4): While executing TSKVRowInputFormat: While executing File. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/TSKVRowInputFormat.cpp:0: DB::TSKVRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012f51ab1 5. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc7d69 6. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73676 7. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 11. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60709 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6eb7f 13. /build/src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000001225e540 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52c77 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 19. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 25. ? @ 0x00007fd9681dd850 2025.09.25 21:25:26.054783 [ 3362 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.213660 [ 3443 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.358575 [ 3259 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.456329 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:26.470435 [ 3399 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.969954 [ 3349 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:26.976820 [ 3031 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.057722 [ 3071 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.215982 [ 2981 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.453164 [ 3444 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.472970 [ 3183 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.554468 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:27.972588 [ 3483 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:27.985273 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.060339 [ 3141 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.229662 [ 3204 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.457787 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.475351 [ 3357 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.646451 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:28.977877 [ 3234 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:28.990618 [ 2996 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.062712 [ 3010 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.235549 [ 3276 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.459442 [ 3040 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.463721 [ 76521 ] {6e3a4ce4-5236-4b46-96ce-5bce4ba65fdd} executeQuery: Code: 206. DB::Exception: JOIN ALL LEFT JOIN ... USING (B) no alias for subquery or table function SELECT 3 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35116) (comment: 01000_subquery_requires_alias.sql) (in query: SELECT * FROM (SELECT 1 as A, 2 as B) X ALL LEFT JOIN (SELECT 3 as A, 2 as B) USING (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110443f1 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110615fe 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:25:29.472238 [ 76521 ] {6e3a4ce4-5236-4b46-96ce-5bce4ba65fdd} TCPHandler: Code: 206. DB::Exception: JOIN ALL LEFT JOIN ... USING (B) no alias for subquery or table function SELECT 3 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110443f1 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110615fe 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:25:29.478512 [ 3292 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.620154 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:29.621319 [ 76521 ] {6f351730-ba7a-4750-b1f1-4a5bcf5b4562} executeQuery: Code: 206. DB::Exception: JOIN ALL LEFT JOIN ... USING (B) no alias for subquery or table function SELECT 1 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) AS Y USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35116) (comment: 01000_subquery_requires_alias.sql) (in query: SELECT * FROM (SELECT 1 as A, 2 as B) ALL LEFT JOIN (SELECT 3 as A, 2 as B) Y USING (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110443f1 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110615a7 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:25:29.622973 [ 76521 ] {6f351730-ba7a-4750-b1f1-4a5bcf5b4562} TCPHandler: Code: 206. DB::Exception: JOIN ALL LEFT JOIN ... USING (B) no alias for subquery or table function SELECT 1 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) AS Y USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 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/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110443f1 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110615a7 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110601e7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103240e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 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*) @ 0x00000000119105a9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 23. ? @ 0x00007fd96814bac3 24. ? @ 0x00007fd9681dd850 2025.09.25 21:25:29.980404 [ 3303 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:29.993102 [ 3297 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.065610 [ 3370 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.241942 [ 3065 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.462393 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.480603 [ 3236 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.845558 [ 7604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:30.983149 [ 3187 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:30.999929 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:31.067944 [ 3427 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:31.295457 [ 3211 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:31.468390 [ 3315 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:31.485339 [ 3029 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:31.887882 [ 8202 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:31.989502 [ 3385 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.001746 [ 3261 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.069510 [ 3205 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.297879 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.470621 [ 3410 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.489422 [ 3202 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:32.811965 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:32.991669 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.005379 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.071994 [ 3000 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.300326 [ 3103 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.472879 [ 3339 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.491195 [ 3291 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:33.808479 [ 4665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:33.995174 [ 3197 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.008111 [ 3275 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.074375 [ 3386 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.303434 [ 3209 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.481902 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.497651 [ 3083 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.848921 [ 7898 ] {8299adc4-fe35-4000-a69c-a2f0952c84f5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50536) (comment: 02876_sort_union_of_sorted.sql) (in query: DROP DATABASE IF EXISTS test_u1sl4h7e ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:25:34.856273 [ 7898 ] {8299adc4-fe35-4000-a69c-a2f0952c84f5} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.933246 [ 77647 ] {c053f8ee-bb6b-4eba-9672-be792beb8a1c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:50552) (comment: 02876_sort_union_of_sorted.sql) (in query: DROP DATABASE IF EXISTS test_u1sl4h7e ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 2025.09.25 21:25:34.935428 [ 77647 ] {c053f8ee-bb6b-4eba-9672-be792beb8a1c} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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) @ 0x0000000011179714 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157525e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000119137f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 18. ? @ 0x00007fd96814bac3 19. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:34.970678 [ 7898 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:34.997718 [ 3414 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.010933 [ 3104 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.076650 [ 3039 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.306661 [ 3254 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.486800 [ 3249 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.512638 [ 3219 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:35.999899 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.006308 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:36.015511 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.091907 [ 3172 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.309256 [ 2968 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.489820 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.517830 [ 3364 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:36.892717 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:37.012279 [ 3322 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.017922 [ 3296 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.093877 [ 3053 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.312078 [ 3094 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.495757 [ 3016 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.519839 [ 3466 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:37.960295 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:38.014595 [ 3270 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.020196 [ 3384 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.099507 [ 3298 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.314329 [ 3361 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.498580 [ 3050 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.521880 [ 3049 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:38.992985 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:39.017206 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.022423 [ 3233 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.079537 [ 77647 ] {0226cfa6-7f01-4bfb-89c0-18c4f3d21c95} executeQuery: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: ALTER TABLE old_style ADD COLUMN y UInt32, MODIFY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a61cb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:25:39.081917 [ 77647 ] {0226cfa6-7f01-4bfb-89c0-18c4f3d21c95} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: 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:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a61cb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 15. ? @ 0x00007fd96814bac3 16. ? @ 0x00007fd9681dd850 2025.09.25 21:25:39.104523 [ 3092 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.320081 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.500752 [ 3333 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.523892 [ 3237 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:39.964594 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.019314 [ 3078 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.024112 [ 3387 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.113492 [ 3308 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.322748 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.504353 [ 3052 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.526057 [ 3232 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:40.543352 [ 77647 ] {35950425-487b-435a-b941-117190410a3d} executeQuery: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing_r1 MODIFY ORDER BY (x, y, -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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e1d8 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.545913 [ 77647 ] {35950425-487b-435a-b941-117190410a3d} TCPHandler: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e1d8 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.860304 [ 77647 ] {f32d9db3-a7f5-499c-a13e-b7735d1e3969} executeQuery: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing_r1 ADD COLUMN z UInt32 DEFAULT x + 1, MODIFY ORDER BY (x, y, -z);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e498 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.863580 [ 77647 ] {f32d9db3-a7f5-499c-a13e-b7735d1e3969} TCPHandler: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::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/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e498 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.889976 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.962947 [ 77647 ] {acd0814d-9359-4895-96e5-8d028b59ff5c} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent' 'x' 'y' 'nonexistent'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: /* Can't add nonexistent column to ORDER BY. */ ALTER TABLE summing_r1 MODIFY ORDER BY (x, y, nonexistent);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000122034dd 6. /build/src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000012202ff0 7. /build/src/Storages/AlterCommands.cpp:610: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000121c766b 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000121cbb5b 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a37e5 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:25:40.967189 [ 77647 ] {acd0814d-9359-4895-96e5-8d028b59ff5c} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent' 'x' 'y' 'nonexistent'. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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) @ 0x000000001187be0a 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 @ 0x0000000011883e35 5. /build/src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000122034dd 6. /build/src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000012202ff0 7. /build/src/Storages/AlterCommands.cpp:610: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000121c766b 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000121cbb5b 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a37e5 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 20. ? @ 0x00007fd96814bac3 21. ? @ 0x00007fd9681dd850 2025.09.25 21:25:41.022181 [ 3371 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.025607 [ 3244 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.049608 [ 77647 ] {64e66ef6-1707-4815-9e4d-e98659bc1d27} executeQuery: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: /* Can't modyfy ORDER BY so that it is no longer a prefix of the PRIMARY KEY. */ ALTER TABLE summing_r1 MODIFY 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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/Storages/MergeTree/MergeTreeData.cpp:589: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e5ac 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:41.061880 [ 77647 ] {64e66ef6-1707-4815-9e4d-e98659bc1d27} TCPHandler: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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/Storages/MergeTree/MergeTreeData.cpp:589: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000001277e5ac 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a4e5f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecca 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:25:41.114829 [ 3042 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.324823 [ 3395 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.506739 [ 3095 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.528497 [ 3382 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:41.889301 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:42.023832 [ 3471 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.030013 [ 3227 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.116239 [ 3287 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.326649 [ 3459 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.508424 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.530181 [ 3490 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:42.824135 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:43.026545 [ 2998 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.032007 [ 3469 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.118485 [ 3136 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.331388 [ 3361 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.512028 [ 2992 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.531782 [ 3248 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:43.795650 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:44.028653 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.044873 [ 3137 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.120469 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.334531 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.514272 [ 3147 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.536425 [ 3237 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:44.812337 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:45.031707 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.053821 [ 3270 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.122561 [ 3350 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.336871 [ 3305 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.524037 [ 3292 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.538512 [ 3052 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:45.779966 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:46.033405 [ 3296 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.056046 [ 3362 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.124585 [ 3053 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.338266 [ 3327 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.526275 [ 3333 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.540891 [ 3331 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:46.825565 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:47.035015 [ 3478 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.057541 [ 3071 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.126106 [ 3391 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.339832 [ 3340 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.528632 [ 3230 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.543243 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:47.901988 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:48.048401 [ 3010 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.059561 [ 3159 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.129345 [ 3288 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.341875 [ 3003 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.530245 [ 3389 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.544973 [ 3232 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:48.769554 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:49.050593 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.073760 [ 3171 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.131812 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.344274 [ 3043 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.532068 [ 3148 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.548379 [ 3299 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:49.664712 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:50.052638 [ 3133 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:50.076406 [ 3077 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:50.133481 [ 3140 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:50.346197 [ 3323 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:50.532502 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:50.535506 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:50.550160 [ 3378 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.054481 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.078034 [ 3096 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.135270 [ 3435 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.347830 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.450762 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:51.537694 [ 3126 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:51.552518 [ 3117 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.056417 [ 3343 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.082373 [ 3014 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.137375 [ 3108 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.351083 [ 3200 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.467961 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:52.543405 [ 2982 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:52.555446 [ 3102 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.058347 [ 3312 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.084062 [ 3170 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.139239 [ 3393 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.383044 [ 3032 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.404801 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:53.545455 [ 3335 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:53.557303 [ 3122 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.065528 [ 3443 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.085897 [ 3266 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.142071 [ 3112 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.388664 [ 3228 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.541207 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:54.547890 [ 3106 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:54.560149 [ 3400 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.068354 [ 3186 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.088301 [ 3066 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.144478 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.424103 [ 3151 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.519061 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:55.550440 [ 3264 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:55.565950 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.071159 [ 3092 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.090590 [ 3406 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.147285 [ 3161 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.426284 [ 3489 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.552532 [ 3290 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.567975 [ 3373 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:56.596580 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:57.073715 [ 3211 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.096238 [ 3037 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.150021 [ 3054 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.428720 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.555167 [ 3311 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.578452 [ 2983 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:57.763955 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:58.076528 [ 3444 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.099045 [ 3068 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.151900 [ 3040 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.434743 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.567811 [ 3155 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.581831 [ 3174 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:58.967676 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:25:59.078899 [ 3090 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.101059 [ 3272 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.153550 [ 3399 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.436791 [ 3018 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.570404 [ 2969 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.584679 [ 3215 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:25:59.910911 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:00.089853 [ 3291 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.109889 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.158602 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.438914 [ 3271 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.573280 [ 3458 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.589606 [ 3097 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:00.940687 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:01.092378 [ 3289 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.112147 [ 3258 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.163897 [ 3195 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.441611 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.575989 [ 3101 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.600157 [ 3368 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:01.886196 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:02.097956 [ 3370 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.117498 [ 3172 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.168764 [ 3111 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.444718 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.583014 [ 3382 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.602425 [ 3337 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:02.793186 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:03.100475 [ 3481 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.120034 [ 3214 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.175375 [ 3170 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.448733 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.584841 [ 3488 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.604218 [ 3175 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:03.737922 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:04.102445 [ 3000 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.122731 [ 3350 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.178151 [ 3116 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.454139 [ 3177 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.587305 [ 3122 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.606555 [ 3400 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:04.828678 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:05.106284 [ 3039 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.124777 [ 3464 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.194458 [ 2979 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.456937 [ 3444 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.589594 [ 3146 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.608788 [ 3150 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:05.969960 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:06.109076 [ 3044 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:06.127026 [ 3391 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:06.197142 [ 3324 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:06.460116 [ 3068 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:06.592179 [ 3008 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:06.611384 [ 3363 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.007841 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:07.113330 [ 3077 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.128713 [ 3442 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.200327 [ 3266 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.462768 [ 3173 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.594618 [ 3290 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:07.613930 [ 2983 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.115577 [ 3136 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.130960 [ 3298 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.153045 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:08.202549 [ 3204 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.468500 [ 3272 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.597631 [ 3155 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:08.616393 [ 2967 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.118037 [ 3096 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.133896 [ 3435 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.205161 [ 3079 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.325946 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:09.471289 [ 3399 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.603620 [ 3154 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:09.621585 [ 3174 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.123446 [ 3169 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.136655 [ 3482 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.208247 [ 3026 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.405368 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:10.474203 [ 3410 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.606574 [ 3081 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:10.624023 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.125940 [ 3343 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.142268 [ 3014 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.210809 [ 3186 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.480247 [ 3022 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.609279 [ 2989 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:11.617673 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:11.626729 [ 3375 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.128674 [ 3180 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.145094 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.213278 [ 3046 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.483010 [ 3236 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.612010 [ 3388 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.629712 [ 3119 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:12.777561 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:13.134110 [ 3463 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.151695 [ 3246 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.219918 [ 3206 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.486153 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.607497 [ 77647 ] {bc6c8f25-0f55-4f08-92c0-bd47ab3e6263} executeQuery: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Timeout exceeded while waiting for replicas r2 to process entry log-0000000003. Probably some replicas are inactive. (UNFINISHED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: ALTER TABLE summing_r1 ADD COLUMN t UInt32 AFTER z, MODIFY ORDER BY (x, y, t * t) SETTINGS replication_alter_partitions_sync = 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000001244b2eb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitForAllReplicasToProcessLogEntry(String const&, DB::ReplicatedMergeTreeLogEntryData const&, long, String const&) @ 0x00000000123f279a 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000123d850d 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123ddebc 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecf9 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:13.614655 [ 3373 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.614870 [ 77647 ] {bc6c8f25-0f55-4f08-92c0-bd47ab3e6263} TCPHandler: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Timeout exceeded while waiting for replicas r2 to process entry log-0000000003. Probably some replicas are inactive. (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000001244b2eb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::waitForAllReplicasToProcessLogEntry(String const&, DB::ReplicatedMergeTreeLogEntryData const&, long, String const&) @ 0x00000000123f279a 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000123d850d 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123ddebc 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153ecf9 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d00d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:13.632337 [ 3287 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:13.932570 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:14.136716 [ 3356 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.153775 [ 3405 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.221557 [ 3123 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.474863 [ 77647 ] {ab79971c-4ae6-408c-9085-3b7abdc1e5f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=751). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:60734) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: SHOW CREATE TABLE summing_r2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:26:14.477571 [ 77647 ] {ab79971c-4ae6-408c-9085-3b7abdc1e5f9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=782, jobs=751). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 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: ? @ 0x0000000012d6d149 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d4b9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf099 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb52a7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 2025.09.25 21:26:14.489033 [ 3018 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.617328 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.636031 [ 3440 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:14.716999 [ 7898 ] {4c30e4a7-2419-4d17-91fc-5c830a0d6f1a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:36588) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_hd1d8wa2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 2025.09.25 21:26:14.719572 [ 7898 ] {4c30e4a7-2419-4d17-91fc-5c830a0d6f1a} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011574e5b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115716c8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570e51 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570925 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 21. ? @ 0x00007fd96814bac3 22. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.136561 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:15.139522 [ 3037 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.166498 [ 3015 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.223447 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.492272 [ 3339 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.619749 [ 3023 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:15.655644 [ 3166 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.146371 [ 3327 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.169142 [ 3340 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.225851 [ 3259 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.348318 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:16.494783 [ 3383 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.603271 [ 82242 ] {3fa315cb-1ffe-4e1a-8249-5882f2df4d51} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:41066) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '2', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_2' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_2' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:16.622609 [ 3289 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:16.630336 [ 82242 ] {3fa315cb-1ffe-4e1a-8249-5882f2df4d51} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:16.658405 [ 3258 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.149593 [ 3338 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.202896 [ 3309 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.227935 [ 3416 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.497301 [ 3336 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.498723 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:17.627968 [ 3195 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.660701 [ 3487 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:17.925682 [ 82242 ] {ec5e6a19-1799-47cc-9aa8-d4d8976a2cc6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57840) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '3', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_3' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_3' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:26:17.961844 [ 82242 ] {ec5e6a19-1799-47cc-9aa8-d4d8976a2cc6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906a25 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:26:18.155991 [ 3371 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.206269 [ 3402 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.230261 [ 3448 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.503730 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.590304 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:18.630644 [ 3437 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.654673 [ 7898 ] {} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/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&&) @ 0x0000000010886c6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010886177 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885823 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 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&) @ 0x0000000012c4bf65 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 16. ? @ 0x00007fd96814bac3 17. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.666586 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:18.972722 [ 3217 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.161993 [ 3083 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.208901 [ 3117 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.232752 [ 3335 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.515774 [ 2985 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.633482 [ 2978 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.669486 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:19.787949 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:19.978784 [ 2996 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.166640 [ 3411 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.210900 [ 3303 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.243398 [ 3216 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.356078 [ 82242 ] {79522eef-c7c3-48a6-bf38-6dc951832282} 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.10508.altinitytest (altinity build)) (from [::1]:57898) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '5', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_5' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_5' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011040a7c 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392ef 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c664 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 24. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 2025.09.25 21:26:20.365351 [ 82242 ] {79522eef-c7c3-48a6-bf38-6dc951832282} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bade 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fec2f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175408 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174bee 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011040a7c 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110392ef 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c664 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000011038e9c 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011037fe0 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e369 24. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103247e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000110317d9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110310ae 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583caa 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&) @ 0x0000000011647c56 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646149 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&) @ 0x0000000011648a44 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f1ec4 2025.09.25 21:26:20.521444 [ 3101 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.635593 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.671412 [ 3401 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:20.740643 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:20.982832 [ 3349 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.133810 [ 82242 ] {625bb4b4-d154-4509-a27b-4466a7bde666} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57910) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '6', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_6' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_6' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:21.152692 [ 82242 ] {625bb4b4-d154-4509-a27b-4466a7bde666} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:21.176369 [ 3116 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.212412 [ 2981 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.245194 [ 3455 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.523918 [ 3049 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.639780 [ 3407 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.655785 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:21.673276 [ 3325 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:21.984401 [ 3031 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.056194 [ 82242 ] {cf168555-5d77-4f1f-9284-7a29f99fa5b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57916) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '7', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_7' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_7' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:22.077763 [ 82242 ] {cf168555-5d77-4f1f-9284-7a29f99fa5b1} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128536a5 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) @ 0x000000001318dc24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318cb64 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318c973 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319251f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000131939a9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001315574d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174e23 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164852d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116482de 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c3bd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb517b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 25. ? @ 0x00007fd96814bac3 26. ? @ 0x00007fd9681dd850 2025.09.25 21:26:22.179987 [ 2979 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.213846 [ 3443 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.246821 [ 3472 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.525605 [ 3192 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.535589 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:22.649642 [ 3375 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.674992 [ 3341 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:22.988008 [ 3217 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.182809 [ 3109 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.216108 [ 3266 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.257795 [ 3405 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.527907 [ 3230 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.579997 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:23.652772 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:23.711397 [ 3468 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.001632 [ 3114 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.185685 [ 3463 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.218416 [ 3428 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.260499 [ 3082 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.507636 [ 82242 ] {8dbd935a-c321-48ed-91e5-7587b349e7ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:57950) (comment: 02871_peak_threads_usage.sh) (in query: SELECT '9', peak_threads_usage, (select count() from system.query_thread_log WHERE system.query_thread_log.query_id = '02871_1_81929_9' AND current_database = currentDatabase()) = length(thread_ids), length(thread_ids) >= peak_threads_usage FROM system.query_log WHERE type = 'QueryFinish' AND query_id = '02871_1_81929_9' 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:26:24.530472 [ 3237 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.579382 [ 82242 ] {8dbd935a-c321-48ed-91e5-7587b349e7ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=3): 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906c5e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b48ae 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d0ddb 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x000000001290475d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5620 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52a47 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6af69 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60c10 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d60e9d 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d617ff 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 2025.09.25 21:26:24.655398 [ 3283 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.715045 [ 3035 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:24.794162 [ 82242 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:25.004198 [ 3197 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.189260 [ 3076 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.222723 [ 3204 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.262896 [ 3294 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.533029 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.658135 [ 3001 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:25.717743 [ 3300 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.006579 [ 3125 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.026313 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:26.194440 [ 3324 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.225152 [ 3326 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.265493 [ 3425 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.536408 [ 3052 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.664151 [ 3097 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:26.720249 [ 3142 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.018500 [ 3145 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.197022 [ 3393 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.228014 [ 3276 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.258803 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:27.268582 [ 3182 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.539196 [ 3268 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.666952 [ 3166 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:27.722698 [ 3129 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.021251 [ 2998 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.199996 [ 3026 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.230793 [ 3046 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.271616 [ 3190 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.390705 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:28.541522 [ 3232 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.672605 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:28.726716 [ 3198 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.024829 [ 3381 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.202310 [ 3418 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.234690 [ 3107 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.274902 [ 3477 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.286563 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:29.543899 [ 3148 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.674996 [ 3124 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:29.728886 [ 2964 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.027024 [ 3322 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.204550 [ 3406 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.241007 [ 3387 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.277000 [ 2984 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.366156 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:30.546210 [ 3061 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.677967 [ 3240 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:30.735965 [ 2965 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.029294 [ 3137 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.206855 [ 3211 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.267360 [ 3308 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.284156 [ 3037 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.558503 [ 3034 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.651270 [ 77647 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:31.680918 [ 3048 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:31.741858 [ 3089 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.031738 [ 3270 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.209859 [ 3209 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.269363 [ 3021 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.285932 [ 2968 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.560562 [ 3279 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.582112 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:32.682704 [ 3368 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:32.744738 [ 3247 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.033929 [ 3384 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.213051 [ 3176 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.272113 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.288649 [ 3015 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.562830 [ 2982 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.691591 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:33.722505 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:33.747500 [ 3412 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.036809 [ 3071 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.216082 [ 3239 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.279700 [ 3340 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.297737 [ 3278 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.568421 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.655785 [ 4905 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885c93 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885576 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885888 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9474 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e996b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7c33 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbd6f0 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4aaa 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccb939 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:26:34.694146 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:34.749867 [ 3476 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.043967 [ 3481 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.218537 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.285935 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.300337 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.571771 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.697109 [ 3143 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:35.755319 [ 3047 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.049505 [ 3171 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.225977 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.288633 [ 3377 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.302836 [ 3105 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.574544 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.706622 [ 3379 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:36.769446 [ 3319 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.052183 [ 3350 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.228477 [ 3068 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.294105 [ 3329 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.305589 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.581054 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.730089 [ 3187 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:37.772090 [ 3184 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.054450 [ 3014 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.280976 [ 3448 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.296487 [ 3090 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.310748 [ 3330 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.583758 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.734891 [ 3134 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:38.779155 [ 3162 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.059659 [ 3152 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.283727 [ 3147 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.299457 [ 3242 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.313270 [ 3016 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.585857 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.732186 [ 3595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1f5dde2e-b2d7-4e9d-9554-6a73596d18e1::202509_305_315_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 28. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.744687 [ 3360 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:39.781763 [ 3354 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.061958 [ 3013 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.288920 [ 3078 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.302187 [ 3103 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.319788 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.600258 [ 3020 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.751341 [ 3224 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:40.786216 [ 3470 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.065088 [ 3141 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.291672 [ 3269 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.304668 [ 3209 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.331246 [ 3007 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.603560 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.757289 [ 3255 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:41.789038 [ 3074 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.068253 [ 3346 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.294660 [ 2984 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.307035 [ 3196 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.334205 [ 3431 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.338367 [ 3589 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c4b482f-5c1e-43bc-a4e0-a981a95d28b4::202509_171_192_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012757f76 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275865d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275bd18 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bab9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007fd96814bac3 29. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.606407 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.760227 [ 3430 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:42.794362 [ 3127 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.070960 [ 3010 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.297556 [ 3211 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.309389 [ 3213 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.336731 [ 3239 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.622161 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.765186 [ 3376 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:43.796916 [ 3193 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.073231 [ 3370 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.300189 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.314422 [ 3176 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.341981 [ 3030 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.687986 [ 3475 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.769472 [ 3260 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:44.805917 [ 3036 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.078297 [ 3427 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.307843 [ 3015 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.317418 [ 3396 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.344388 [ 3165 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.690624 [ 3452 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.772665 [ 3198 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:45.811480 [ 3403 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.080706 [ 3438 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.320287 [ 3003 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.346929 [ 3238 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.398987 [ 3305 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.693703 [ 3447 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.777890 [ 3067 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:46.813982 [ 3033 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.083557 [ 3205 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.322986 [ 3323 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.349955 [ 3338 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.402151 [ 3151 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.696850 [ 3282 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.780774 [ 3241 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:47.816799 [ 3332 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.086114 [ 3000 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.332879 [ 2986 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.352441 [ 3394 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.404697 [ 3409 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.699607 [ 3124 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.787189 [ 3098 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:48.819524 [ 2988 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.089721 [ 3039 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.335250 [ 3344 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.361025 [ 3207 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.407338 [ 3019 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.716045 [ 3468 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.789974 [ 3048 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:49.822120 [ 3025 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.092283 [ 3044 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.337834 [ 3355 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.363753 [ 3416 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.410388 [ 3377 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.725400 [ 3129 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.796167 [ 3426 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:50.824618 [ 3422 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.094965 [ 3214 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.340843 [ 3228 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.366310 [ 3194 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.413440 [ 3105 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.728337 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.799277 [ 2994 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:51.827236 [ 3153 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.097627 [ 3140 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.368748 [ 3060 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.408639 [ 3157 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.416097 [ 2966 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.730829 [ 3398 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.806660 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:52.833401 [ 3135 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.100503 [ 3096 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.371054 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.411150 [ 3208 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.424709 [ 3223 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.744639 [ 3028 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.809443 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:53.836639 [ 3429 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.106253 [ 3014 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.383064 [ 3183 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.422919 [ 3410 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.430159 [ 3022 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.747359 [ 3439 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.814928 [ 3342 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:54.839610 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.108900 [ 3108 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.385665 [ 3357 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.425410 [ 3292 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.432780 [ 3235 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.750465 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.827226 [ 3374 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:55.842296 [ 3218 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.111510 [ 3111 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.388135 [ 3392 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.428298 [ 3018 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.435526 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.761972 [ 3144 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.835836 [ 3411 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:56.847581 [ 3345 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.113215 [ 3312 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.390238 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.437767 [ 3420 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.504051 [ 3083 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.764414 [ 3385 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.837705 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:57.849940 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.118492 [ 3116 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.395453 [ 3389 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.440293 [ 3336 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.506434 [ 3232 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.766658 [ 3433 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.840163 [ 3145 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:58.852423 [ 3284 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.121192 [ 2979 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.401261 [ 3299 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.444594 [ 3061 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.509238 [ 3378 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.780953 [ 3109 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.842600 [ 3246 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:26:59.854711 [ 3066 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.133729 [ 3316 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.406837 [ 3004 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.447521 [ 3113 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.512600 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.783876 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.844890 [ 3227 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:00.856826 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.136431 [ 3458 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.408677 [ 3258 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.470854 [ 3185 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.514926 [ 3325 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.786094 [ 2974 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.847703 [ 3353 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:01.859324 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.138184 [ 3435 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.411335 [ 3377 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.473026 [ 3419 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.520413 [ 3252 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.789199 [ 3127 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.850351 [ 3480 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:02.865677 [ 3437 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.142205 [ 3482 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.414033 [ 3302 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.475959 [ 3022 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.523177 [ 3466 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.792197 [ 3241 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.858761 [ 3436 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:03.868387 [ 2975 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.144826 [ 3457 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.417058 [ 3194 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.482296 [ 3292 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.529533 [ 3364 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.797828 [ 3193 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.861661 [ 3310 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:04.870833 [ 3417 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.149080 [ 3343 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.419492 [ 3318 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.488300 [ 3441 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.532393 [ 3230 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.800722 [ 3048 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.864491 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:05.873895 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.151825 [ 3286 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.422403 [ 3060 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.491794 [ 3202 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.535008 [ 3237 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.806392 [ 3415 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.867881 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:06.880853 [ 3231 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.154487 [ 3108 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.425916 [ 3371 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.497756 [ 3083 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.537904 [ 3389 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.809618 [ 3201 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.881821 [ 3225 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:07.883967 [ 3247 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.157434 [ 3162 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.428380 [ 3073 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.499704 [ 3383 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.541090 [ 3268 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.812484 [ 3365 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.884147 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:08.885876 [ 3424 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.161147 [ 3111 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.430847 [ 2966 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.502193 [ 3251 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.551394 [ 3148 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.815305 [ 3033 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.886217 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:09.888037 [ 2985 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.163770 [ 3233 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.433145 [ 3244 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.506298 [ 3152 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.553755 [ 3061 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.817803 [ 3332 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.889141 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:10.890403 [ 3397 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.166279 [ 3170 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.435921 [ 3221 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.508928 [ 3249 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.559357 [ 3004 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.823442 [ 3422 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.894881 [ 2978 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:11.895549 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.169401 [ 3109 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.440184 [ 3057 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.515092 [ 2992 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.562138 [ 3179 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.826614 [ 3085 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.897769 [ 3479 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:12.898757 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.175839 [ 3263 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.442870 [ 3208 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.517706 [ 3181 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.564776 [ 3034 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.830110 [ 3490 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.900639 [ 3465 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:13.926153 [ 3063 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.178219 [ 3112 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.445656 [ 3173 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.581968 [ 3488 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.582666 [ 3122 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.832929 [ 2987 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.903159 [ 3055 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:14.928935 [ 3342 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.183564 [ 3418 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.464385 [ 3315 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.584547 [ 3020 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.588171 [ 3400 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.835586 [ 3130 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.904999 [ 3262 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:15.931968 [ 3059 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.185785 [ 3107 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.467174 [ 3313 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.594041 [ 3363 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.596652 [ 3099 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.837475 [ 3138 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.909021 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:16.933981 [ 3100 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.188742 [ 3472 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.469622 [ 3183 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.612397 [ 2983 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.613301 [ 3041 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.908624 [ 3187 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.912011 [ 3216 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:17.936306 [ 3297 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.194671 [ 3092 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.472597 [ 3410 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.616468 [ 3155 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.615061 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.910401 [ 3352 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.914076 [ 3197 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:18.938241 [ 3280 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.197348 [ 3453 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.474540 [ 3357 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.622912 [ 2969 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.628814 [ 3215 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.915349 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.919495 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:19.944681 [ 3171 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.202872 [ 3069 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.479596 [ 3029 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.625529 [ 3388 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.631160 [ 3285 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.918880 [ 3077 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.921769 [ 3214 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:20.947492 [ 3053 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.205178 [ 3190 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.482976 [ 3330 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.629341 [ 3271 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.634052 [ 3459 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.921398 [ 3078 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.924689 [ 3120 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:21.949667 [ 3269 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.207687 [ 3123 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.488721 [ 3087 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.632162 [ 3013 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.644834 [ 3258 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.923919 [ 3259 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.927049 [ 3043 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:22.953549 [ 3338 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.210057 [ 3355 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.493985 [ 3049 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.634939 [ 3409 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.647934 [ 3392 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.926609 [ 3378 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.933139 [ 3113 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:23.956123 [ 3279 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.212681 [ 3335 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.500692 [ 3420 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.637777 [ 3081 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.650679 [ 3287 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.930179 [ 3367 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.935927 [ 3222 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:24.961966 [ 3163 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.215252 [ 3443 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.502784 [ 3383 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.640086 [ 3407 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.652545 [ 3271 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.936154 [ 3047 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.938876 [ 3379 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:25.965742 [ 3320 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.218799 [ 2981 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.504901 [ 3251 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.642752 [ 3215 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.657130 [ 3001 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.938948 [ 3342 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.942329 [ 3304 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:26.971905 [ 3345 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.224258 [ 3295 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.511743 [ 3152 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.648694 [ 3285 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.670275 [ 3458 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.941878 [ 3319 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.946280 [ 3130 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:27.975246 [ 3449 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.227473 [ 3266 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.514713 [ 3242 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.651619 [ 3283 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.672704 [ 3325 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.944563 [ 2997 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.954374 [ 3262 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:28.977636 [ 3245 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.229916 [ 3326 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.520627 [ 3252 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.666712 [ 3413 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.675551 [ 3341 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.946541 [ 3188 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.963969 [ 3138 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:29.980195 [ 3217 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.232100 [ 3026 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.523320 [ 3466 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.669665 [ 3289 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.679161 [ 3475 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.948973 [ 3374 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.966217 [ 3445 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:30.982725 [ 3234 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.237856 [ 3246 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.525551 [ 3253 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.672541 [ 3366 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.681741 [ 3452 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.951283 [ 3218 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.968806 [ 3100 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:31.985181 [ 2996 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.240454 [ 3065 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.530101 [ 3333 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.683957 [ 3447 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.721843 [ 3142 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.953472 [ 3059 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.970868 [ 3187 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:32.987573 [ 3303 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.245194 [ 3206 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.532470 [ 3248 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.724147 [ 3009 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.778563 [ 3277 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.955723 [ 3144 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.972919 [ 3216 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:33.989784 [ 3297 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.256145 [ 3472 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.534469 [ 3237 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.728473 [ 3301 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.781548 [ 3372 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.958154 [ 3164 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.978002 [ 3273 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:34.992328 [ 3473 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.257826 [ 3405 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.536489 [ 3268 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.734517 [ 2970 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.787084 [ 2990 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.960834 [ 3411 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.981219 [ 3274 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:35.994810 [ 3114 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.260127 [ 3082 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.538999 [ 3232 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.737389 [ 3203 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.789466 [ 3127 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.966665 [ 3184 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:36.984196 [ 3261 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.003493 [ 3352 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.267157 [ 3257 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.540986 [ 3148 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.740232 [ 3038 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.796203 [ 3089 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.968874 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:37.987377 [ 3101 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.005513 [ 2998 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.269333 [ 3294 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.543090 [ 2991 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.750624 [ 3426 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.798697 [ 3168 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.970306 [ 3296 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:38.988671 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.010674 [ 3384 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.272580 [ 3425 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.546033 [ 3378 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.753439 [ 3201 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.801289 [ 3365 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.972567 [ 3071 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:39.991014 [ 3156 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.013371 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.275531 [ 3190 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.549863 [ 3265 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.758123 [ 2994 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.806050 [ 3390 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.978367 [ 3171 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:40.993661 [ 3172 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.016145 [ 3306 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.281574 [ 3316 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.552129 [ 3117 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.764111 [ 3080 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.807942 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.981215 [ 3298 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:41.996672 [ 3096 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.018847 [ 3435 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.283966 [ 3477 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.554772 [ 3102 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.766908 [ 2985 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.810383 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:42.983792 [ 3343 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.008334 [ 3180 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.021415 [ 3404 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.289375 [ 3120 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.557597 [ 3095 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.769883 [ 3085 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.816467 [ 3012 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:43.986596 [ 3286 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.011695 [ 3108 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.023997 [ 3162 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.292377 [ 3308 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.560073 [ 3281 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.772777 [ 3063 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.819581 [ 3161 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:44.992365 [ 3021 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.017742 [ 3094 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.038993 [ 3361 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.297411 [ 3305 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.562813 [ 3084 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.775764 [ 3278 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.822470 [ 3238 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:45.994811 [ 3314 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.020469 [ 3309 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.041388 [ 3032 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.300222 [ 3118 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.565585 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.778283 [ 3380 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.831386 [ 3432 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:46.999734 [ 3019 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.022610 [ 3392 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.043752 [ 3377 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.303566 [ 3402 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.570527 [ 3008 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.781010 [ 3339 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:47.833731 [ 3087 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.004814 [ 3083 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.025075 [ 3192 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.046236 [ 2967 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.306064 [ 3174 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.577965 [ 3126 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.783772 [ 2990 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:48.838948 [ 3088 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.007534 [ 3125 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.030150 [ 3321 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.049162 [ 3270 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.308407 [ 3196 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.581070 [ 3471 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.789096 [ 3127 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:49.841292 [ 3347 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.010325 [ 3275 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.032287 [ 3469 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.055549 [ 3027 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.323410 [ 3254 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.583937 [ 3488 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.792056 [ 3241 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:50.843881 [ 2999 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.013281 [ 3433 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.034567 [ 3381 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.058775 [ 3071 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.328037 [ 3176 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.587514 [ 3227 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.854271 [ 3193 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:51.855257 [ 3153 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.016087 [ 3104 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.037287 [ 3296 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.062114 [ 3141 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.330218 [ 3015 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.593250 [ 3122 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.857190 [ 3398 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:52.857908 [ 3437 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.018801 [ 3145 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.043519 [ 3328 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.067452 [ 3370 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.334934 [ 3431 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.595907 [ 3149 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.860041 [ 2975 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:53.860213 [ 3417 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.021688 [ 3284 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.047007 [ 3137 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.069955 [ 3438 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.337871 [ 3305 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.601087 [ 3020 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.863420 [ 3243 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:54.863526 [ 3064 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.025043 [ 2998 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.049631 [ 3384 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.072447 [ 3086 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.348598 [ 3030 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.604072 [ 3175 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.869725 [ 3225 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:55.871878 [ 3231 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.028411 [ 3401 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.055358 [ 3171 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.074998 [ 3133 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.351767 [ 3340 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.606632 [ 3150 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.872660 [ 3051 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:56.874251 [ 3454 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.037569 [ 3044 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.058233 [ 3306 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.078291 [ 3077 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.354336 [ 3003 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.608670 [ 3363 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.875490 [ 3080 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.877206 [ 3424 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:57.915376 [ 7604 ] {1a425a99-4d92-4a60-9ac7-653fc6999d4c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 146.516714938 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:35174) (comment: 03236_squashing_high_memory.sql) (in query: CREATE TABLE id_values ENGINE = MergeTree ORDER BY id1 SETTINGS index_granularity = 10939, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 31, min_bytes_for_full_part_storage = 391565452, compact_parts_max_bytes_to_buffer = 207286493, compact_parts_max_granules_to_buffer = 64, compact_parts_merge_max_bytes_to_prefetch_part = 4157011, merge_max_block_size = 10557, old_parts_lifetime = 449., 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 = 1, index_granularity_bytes = 6768299, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 71696, primary_key_compress_block_size = 45605 AS SELECT arrayJoin(range(500000)) AS id1, arrayJoin(range(1000)) AS id2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:27:58.040491 [ 3214 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.060431 [ 3053 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.084397 [ 3288 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.357182 [ 3259 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.495695 [ 7604 ] {1a425a99-4d92-4a60-9ac7-653fc6999d4c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 146.516714938 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 7. /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*) @ 0x0000000012d5eba7 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:27:58.612625 [ 3290 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.878635 [ 3456 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:58.880298 [ 3121 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.043617 [ 3442 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.063325 [ 3298 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.087362 [ 3435 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.366221 [ 3220 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.616108 [ 2983 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.894034 [ 3210 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:27:59.895075 [ 2985 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.046563 [ 3169 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.066254 [ 3482 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.090371 [ 3457 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.368950 [ 3199 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.618571 [ 3041 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.896731 [ 3348 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:00.898364 [ 3397 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.049272 [ 3343 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.078141 [ 3423 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.093266 [ 3286 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.371327 [ 3394 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.621250 [ 2967 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.899593 [ 3476 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:01.904245 [ 3011 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.056821 [ 3475 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.095687 [ 3472 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.096435 [ 3479 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.373457 [ 3448 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.624143 [ 3407 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.902294 [ 3047 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:02.907183 [ 3222 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.062534 [ 3263 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.100676 [ 3307 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.101869 [ 3393 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.374286 [ 3200 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.628105 [ 3120 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.903478 [ 3284 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:03.908468 [ 2998 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.063560 [ 3141 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.101835 [ 3044 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.102777 [ 3172 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.374739 [ 3058 ] {} test_hd1d8wa2.old_style (f2d8b978-c2d0-4554-bf77-750321e23846): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_hd1d8wa2/test_00754/old_style/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.628458 [ 3099 ] {} test_13.`02535_custom_key_rmt` (fee2ca8a-e33f-477c-b9aa-03af1d0f9601): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.903792 [ 3385 ] {} test_13.`02535_custom_key_rmt_hash` (f0027701-b5b9-4740-aaf5-a76efa312621): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02535_max_parallel_replicas_custom_key_rmt_test_13/test_02535_hash/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b68e1 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:28:04.908775 [ 3273 ] {} db_01530_atomic.data (619eb081-494b-4bc2-bd9c-2120a56980f1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/db_01530_atomic/db_01530_atomic/data/replicas/test). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344544 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x00000000123b2a26 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967954 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a5b4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096ab87 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007fd96814bac3 12. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:05.105704 [ 83078 ] {9d822eae-0fb9-46cb-8e61-9458c71c9243} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.068996898 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10508.altinitytest (altinity build)) (from [::1]:53066) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:29:05.106003 [ 83078 ] {9d822eae-0fb9-46cb-8e61-9458c71c9243} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.068996898 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::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&&) @ 0x0000000010bfd36b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfca7a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d604d0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5f764 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*) @ 0x0000000012d6ddea 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. ? @ 0x00007fd96814bac3 11. ? @ 0x00007fd9681dd850 2025.09.25 21:29:05.529696 [ 7898 ] {5d8fedeb-6c4e-46ed-bf9e-3b66d7d9b1fe} 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.10508.altinitytest (altinity build)) (from [::1]:59606) (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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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&) @ 0x0000000010dc714e 4. /build/src/Common/atomicRename.cpp:0: DB::renameat2(String const&, String const&, int) @ 0x0000000010dc6f62 5. /build/src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000010dc6b3a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154acaf 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 2025.09.25 21:29:05.530049 [ 7898 ] {5d8fedeb-6c4e-46ed-bf9e-3b66d7d9b1fe} 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::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&) @ 0x0000000010dc714e 4. /build/src/Common/atomicRename.cpp:0: DB::renameat2(String const&, String const&, int) @ 0x0000000010dc6f62 5. /build/src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000010dc6b3a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154acaf 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000115622eb 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d36 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&)>) @ 0x00000000119137f4 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4c723 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f131 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6201 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528987 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000016528e5e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5672 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3383 17. ? @ 0x00007fd96814bac3 18. ? @ 0x00007fd9681dd850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:09.113544 [ 2921 ] {} Application: Closed all listening sockets. Waiting for 39 outstanding connections. 2025.09.25 21:29:14.018406 [ 2921 ] {} Application: Closed connections. But 39 remain. Tip: To increase wait time add to config: 60 2025.09.25 21:29:14.018511 [ 2921 ] {} Application: Will shutdown forcefully. 2025.09.25 21:29:14.545901 [ 83173 ] {} Context: Server was built in debug mode. It will work slowly. 2025.09.25 21:29:14.556125 [ 83173 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.25 21:29:14.556868 [ 83173 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.25 21:29:14.557178 [ 83173 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.25 21:29:14.961439 [ 83173 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.25 21:29:14.965144 [ 83173 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.25 21:29:14.965165 [ 83173 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.25 21:29:15.015629 [ 83765 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.25 21:29:15.701333 [ 83173 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.25 21:29:15.780967 [ 83173 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.09.25 21:29:15.781993 [ 83173 ] {} Context: Server has databases (for example `test_01155_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.09.25 21:29:15.950332 [ 83173 ] {} TablesLoader: Tables test_5.test_distributed, test_5.`.inner_id.d0f92127-191f-4068-a586-2dfa778cdb4c` depend on default.k, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.25 21:29:15.950371 [ 83173 ] {} TablesLoader: Tables test_13.dist_layer_01319 depend on default.sub_key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.25 21:29:15.950392 [ 83173 ] {} TablesLoader: Tables test_3.distributed depend on default.x, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.25 21:29:16.036503 [ 83894 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14): Cannot attach table `test_13`.`merge_tree` from metadata file /var/lib/clickhouse/store/ffc/ffc9115a-364b-4c80-a161-7496747ce71e/merge_tree.sql from query ATTACH TABLE test_13.merge_tree UUID '60192ec9-51d2-424c-855e-2aa3a68b8b91' (`d` Date) ENGINE = MergeTree PARTITION BY d ORDER BY d SETTINGS index_granularity = 25951, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.4179202914237976, replace_long_file_name_to_hash = true, max_file_name_length = 125, min_bytes_for_full_part_storage = 266316400, compact_parts_max_bytes_to_buffer = 200531397, compact_parts_max_granules_to_buffer = 155, compact_parts_merge_max_bytes_to_prefetch_part = 15854928, merge_max_block_size = 2529, 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 = 1, index_granularity_bytes = 9297498, concurrent_part_removal_threshold = 19, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 86608, primary_key_compress_block_size = 67300. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012788da1 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000001278ac51 10. /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>) @ 0x0000000012a75a0c 11. /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>&&) @ 0x0000000012a754d0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 13. /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 @ 0x00000000122534a7 14. /build/contrib/llvm-project/libcxx/include/string:2067: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010dabd3e 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x0000000010dcb2fe 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000010dd2214 17. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 18. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 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. ? @ 0x00007f8759cfdac3 23. ? @ 0x00007f8759d8f850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:16.037774 [ 83941 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): Cannot attach table `test_01155_ordinary`.`src` from metadata file /var/lib/clickhouse/metadata/test_01155_ordinary/src.sql from query ATTACH TABLE test_01155_ordinary.src (`s` String, `x` String DEFAULT 'a') ENGINE = MergeTree PARTITION BY tuple() ORDER BY s SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a252 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>) @ 0x0000000012a75a0c 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>&&) @ 0x0000000012a754d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a713ef 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 @ 0x00000000122534a7 13. /build/contrib/llvm-project/libcxx/include/string:2067: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010dabd3e 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x0000000010dcb2fe 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000010dd2214 16. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 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. ? @ 0x00007f8759cfdac3 22. ? @ 0x00007f8759d8f850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:32.832726 [ 83916 ] {} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.09.25 21:29:32.858462 [ 83916 ] {} Cluster: Code: 198. DB::NetException: Not found address of host: localhosx. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Databases/DatabaseOnDisk.cpp:82: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010dab28b 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x0000000010dcb2fe 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000010dd2214 16. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 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. ? @ 0x00007f8759cfdac3 22. ? @ 0x00007f8759d8f850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:37.410327 [ 83799 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e7d6e632-4c15-41c3-97fd-9f4db39d51ac::202509_1_231_46}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, 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) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x00000000128bf429 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bce27 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcc5f 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) @ 0x00000000128d84ec 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&&) @ 0x0000000012825e6a 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 @ 0x00000000128236fd 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) @ 0x00000000128fb0b7 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&) @ 0x00000000128fdcff 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) @ 0x00000000128fcc63 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127544d3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001275171c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012756df9 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b5ea 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac104 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773124 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773ade 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. ? @ 0x00007f8759cfdac3 28. ? @ 0x00007f8759d8f850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:40.834743 [ 83602 ] {} DNSResolver: Cannot resolve host (localhosx), error 0: Host not found. 2025.09.25 21:29:40.859496 [ 83916 ] {} DNSResolver: Cannot resolve host (localhosy), error 0: Host not found. 2025.09.25 21:29:40.859900 [ 83916 ] {} Cluster: Code: 198. DB::NetException: Not found address of host: localhosy. (DNS_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) @ 0x00000000164833b2 1. /build/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 const&) @ 0x000000000c62c663 3. /build/src/Common/DNSResolver.cpp:112: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000c626825 4. /build/src/Common/DNSResolver.cpp:0: DB::(anonymous namespace)::resolveIPAddressImpl(String const&) @ 0x000000000c62560d 5. /build/src/Common/DNSResolver.cpp:144: DB::(anonymous namespace)::resolveIPAddressWithCache(DB::CacheBase, DB::EqualWeightFunction>&, String const&) @ 0x000000000c625997 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000c6262e9 7. /build/src/Interpreters/Cluster.cpp:0: DB::Cluster::Address::getResolvedAddress() const @ 0x00000000110c7445 8. /build/contrib/llvm-project/libcxx/include/optional:344: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000110c840c 9. /build/contrib/llvm-project/libcxx/include/vector:1614: void std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x00000000110d4b9a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x00000000110cea5f 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000010264ac9 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000104c66f7 13. /build/src/Databases/DatabaseOnDisk.cpp:82: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010dab28b 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x0000000010dcb2fe 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000010dd2214 16. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 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. ? @ 0x00007f8759cfdac3 22. ? @ 0x00007f8759d8f850 (version 24.8.14.10508.altinitytest (altinity build)) 2025.09.25 21:29:42.739326 [ 83173 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164833b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/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: ? @ 0x0000000010403f01 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012515731 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) @ 0x000000001251546d 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000012515244 11. /build/src/Storages/IStorage.h:594: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000010e114ba 12. /build/contrib/llvm-project/libcxx/include/__tree:188: DB::DatabaseCatalog::shutdownImpl() @ 0x0000000011174c43 13. /build/src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x000000001110763b 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() @ 0x0000000016549d86 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. ? @ 0x00007f8759c92d90 21. ? @ 0x00007f8759c92e40 22. _start @ 0x000000000700802e (version 24.8.14.10508.altinitytest (altinity build))